Black Lives Matter
Support the Equal Justice Initiative
Link to Go homepage
  • Why Go
  • Getting Started
  • Discover Packages
  • About
Go.
  • Why Go
  • Getting Started
  • Discover Packages
  • About
  • golang.org
The highest tagged major version is v6.
Discover Packages gopkg.in/olivere/elastic.v5
Go

elastic

package module
Version: v5.0.86
Latest Latest Go to latest
Published: Jul 13, 2020 License: MIT Imports: 30 Imported by: 547
  • README
    • Releases
      • Elastic 5.0
      • Elastic 3.0
      • Elastic 2.0
      • Elastic 1.0
    • Status
    • Getting Started
    • API Status
      • Document APIs
      • Search APIs
      • Aggregations
      • Indices APIs
      • cat APIs
      • Cluster APIs
      • Query DSL
      • Modules
      • Sorting
      • Scrolling
    • How to contribute
    • Credits
    • LICENSE
  • Documentation
    • Overview
    • Index
      • Examples
    • Constants
    • Variables
    • Functions
      • IsConflict(err)
      • IsConnErr(err)
      • IsContextErr(err)
      • IsNotFound(err)
      • IsStatusCode(err, code)
      • IsTimeout(err)
      • Retry(o, b)
      • RetryNotify(operation, b, notify)
    • Types
      • type AcknowledgedResponse
      • type AdjacencyMatrixAggregation
        • NewAdjacencyMatrixAggregation()
        • (a) Filters(name, filter)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type Aggregation
      • type AggregationBucketAdjacencyMatrix
        • (a) UnmarshalJSON(data)
      • type AggregationBucketFilters
        • (a) UnmarshalJSON(data)
      • type AggregationBucketHistogramItem
        • (a) UnmarshalJSON(data)
      • type AggregationBucketHistogramItems
        • (a) UnmarshalJSON(data)
      • type AggregationBucketKeyItem
        • (a) UnmarshalJSON(data)
      • type AggregationBucketKeyItems
        • (a) UnmarshalJSON(data)
      • type AggregationBucketKeyedHistogramItems
        • (a) UnmarshalJSON(data)
      • type AggregationBucketKeyedRangeItems
        • (a) UnmarshalJSON(data)
      • type AggregationBucketRangeItem
        • (a) UnmarshalJSON(data)
      • type AggregationBucketRangeItems
        • (a) UnmarshalJSON(data)
      • type AggregationBucketSignificantTerm
        • (a) UnmarshalJSON(data)
      • type AggregationBucketSignificantTerms
        • (a) UnmarshalJSON(data)
      • type AggregationExtendedStatsMetric
        • (a) UnmarshalJSON(data)
      • type AggregationGeoBoundsMetric
        • (a) UnmarshalJSON(data)
      • type AggregationGeoCentroidMetric
        • (a) UnmarshalJSON(data)
      • type AggregationMatrixStats
        • (a) UnmarshalJSON(data)
      • type AggregationMatrixStatsField
      • type AggregationPercentilesMetric
        • (a) UnmarshalJSON(data)
      • type AggregationPipelineBucketMetricValue
        • (a) UnmarshalJSON(data)
      • type AggregationPipelineDerivative
        • (a) UnmarshalJSON(data)
      • type AggregationPipelinePercentilesMetric
        • (a) UnmarshalJSON(data)
      • type AggregationPipelineSimpleValue
        • (a) UnmarshalJSON(data)
      • type AggregationPipelineStatsMetric
        • (a) UnmarshalJSON(data)
      • type AggregationSingleBucket
        • (a) UnmarshalJSON(data)
      • type AggregationStatsMetric
        • (a) UnmarshalJSON(data)
      • type AggregationTopHitsMetric
        • (a) UnmarshalJSON(data)
      • type AggregationValueMetric
        • (a) UnmarshalJSON(data)
      • type Aggregations
        • (a) AdjacencyMatrix(name)
        • (a) Avg(name)
        • (a) AvgBucket(name)
        • (a) BucketScript(name)
        • (a) Cardinality(name)
        • (a) Children(name)
        • (a) CumulativeSum(name)
        • (a) DateHistogram(name)
        • (a) DateRange(name)
        • (a) Derivative(name)
        • (a) DiversifiedSampler(name)
        • (a) ExtendedStats(name)
        • (a) Filter(name)
        • (a) Filters(name)
        • (a) GeoBounds(name)
        • (a) GeoCentroid(name)
        • (a) GeoDistance(name)
        • (a) GeoHash(name)
        • (a) Global(name)
        • (a) Histogram(name)
        • (a) IPRange(name)
        • (a) KeyedDateHistogram(name)
        • (a) KeyedRange(name)
        • (a) MatrixStats(name)
        • (a) Max(name)
        • (a) MaxBucket(name)
        • (a) Min(name)
        • (a) MinBucket(name)
        • (a) Missing(name)
        • (a) MovAvg(name)
        • (a) Nested(name)
        • (a) PercentileRanks(name)
        • (a) Percentiles(name)
        • (a) PercentilesBucket(name)
        • (a) Range(name)
        • (a) ReverseNested(name)
        • (a) Sampler(name)
        • (a) SerialDiff(name)
        • (a) SignificantTerms(name)
        • (a) Stats(name)
        • (a) StatsBucket(name)
        • (a) Sum(name)
        • (a) SumBucket(name)
        • (a) Terms(name)
        • (a) TopHits(name)
        • (a) ValueCount(name)
      • type AliasAction
      • type AliasAddAction
        • NewAliasAddAction(alias)
        • (a) Filter(filter)
        • (a) Index(index)
        • (a) IndexRouting(routing)
        • (a) Routing(routing)
        • (a) SearchRouting(routing)
        • (a) Source()
        • (a) Validate()
      • type AliasRemoveAction
        • NewAliasRemoveAction(alias)
        • (a) Index(index)
        • (a) Source()
        • (a) Validate()
      • type AliasResult
      • type AliasService
        • NewAliasService(client)
        • (s) Action(action)
        • (s) Add(indexName, aliasName)
        • (s) AddWithFilter(indexName, aliasName, filter)
        • (s) Do(ctx)
        • (s) Pretty(pretty)
        • (s) Remove(indexName, aliasName)
      • type AliasesResult
        • (ar) IndicesByAlias(aliasName)
      • type AliasesService
        • NewAliasesService(client)
        • (s) Do(ctx)
        • (s) Index(index)
        • (s) Pretty(pretty)
      • type AvgAggregation
        • NewAvgAggregation()
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type AvgBucketAggregation
        • NewAvgBucketAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type Backoff
      • type BackoffFunc
      • type BackoffRetrier
        • NewBackoffRetrier(backoff)
        • (r) Retry(ctx, retry, req, resp, err)
      • type BoolQuery
        • NewBoolQuery()
        • (q) AdjustPureNegative(adjustPureNegative)
        • (q) Boost(boost)
        • (q) DisableCoord(disableCoord)
        • (q) Filter(filters)
        • (q) MinimumNumberShouldMatch(minimumNumberShouldMatch)
        • (q) MinimumShouldMatch(minimumShouldMatch)
        • (q) Must(queries)
        • (q) MustNot(queries)
        • (q) QueryName(queryName)
        • (q) Should(queries)
        • (q) Source()
      • type BoostingQuery
        • NewBoostingQuery()
        • (q) Boost(boost)
        • (q) Negative(negative)
        • (q) NegativeBoost(negativeBoost)
        • (q) Positive(positive)
        • (q) Source()
      • type BucketScriptAggregation
        • NewBucketScriptAggregation()
        • (a) AddBucketsPath(name, path)
        • (a) BucketsPathsMap(bucketsPathsMap)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type BucketSelectorAggregation
        • NewBucketSelectorAggregation()
        • (a) AddBucketsPath(name, path)
        • (a) BucketsPathsMap(bucketsPathsMap)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type BulkAfterFunc
      • type BulkBeforeFunc
      • type BulkDeleteRequest
        • NewBulkDeleteRequest()
        • (r) Id(id)
        • (r) Index(index)
        • (r) Parent(parent)
        • (r) Routing(routing)
        • (r) Source()
        • (r) String()
        • (r) Type(typ)
        • (r) UseEasyJSON(enable)
        • (r) Version(version)
        • (r) VersionType(versionType)
      • type BulkIndexByScrollResponse
      • type BulkIndexRequest
        • NewBulkIndexRequest()
        • (r) Doc(doc)
        • (r) Id(id)
        • (r) Index(index)
        • (r) OpType(opType)
        • (r) Parent(parent)
        • (r) Pipeline(pipeline)
        • (r) RetryOnConflict(retryOnConflict)
        • (r) Routing(routing)
        • (r) Source()
        • (r) String()
        • (r) TTL(ttl)
        • (r) Type(typ)
        • (r) UseEasyJSON(enable)
        • (r) Version(version)
        • (r) VersionType(versionType)
      • type BulkProcessor
        • (p) Add(request)
        • (p) Close()
        • (p) Flush()
        • (p) Start(ctx)
        • (p) Stats()
        • (p) Stop()
      • type BulkProcessorService
        • NewBulkProcessorService(client)
        • (s) After(fn)
        • (s) Backoff(backoff)
        • (s) Before(fn)
        • (s) BulkActions(bulkActions)
        • (s) BulkSize(bulkSize)
        • (s) Do(ctx)
        • (s) FlushInterval(interval)
        • (s) Name(name)
        • (s) Stats(wantStats)
        • (s) Workers(num)
      • type BulkProcessorStats
      • type BulkProcessorWorkerStats
      • type BulkResponse
        • (r) ByAction(action)
        • (r) ById(id)
        • (r) Created()
        • (r) Deleted()
        • (r) Failed()
        • (r) Indexed()
        • (r) Succeeded()
        • (r) Updated()
      • type BulkResponseItem
      • type BulkService
        • NewBulkService(client)
        • (s) Add(requests)
        • (s) Do(ctx)
        • (s) EstimatedSizeInBytes()
        • (s) Index(index)
        • (s) NumberOfActions()
        • (s) Pipeline(pipeline)
        • (s) Pretty(pretty)
        • (s) Refresh(refresh)
        • (s) Reset()
        • (s) Retrier(retrier)
        • (s) Routing(routing)
        • (s) Timeout(timeout)
        • (s) Type(typ)
        • (s) WaitForActiveShards(waitForActiveShards)
      • type BulkUpdateRequest
        • NewBulkUpdateRequest()
        • (r) DetectNoop(detectNoop)
        • (r) Doc(doc)
        • (r) DocAsUpsert(docAsUpsert)
        • (r) Id(id)
        • (r) Index(index)
        • (r) Parent(parent)
        • (r) RetryOnConflict(retryOnConflict)
        • (r) ReturnSource(source)
        • (r) Routing(routing)
        • (r) Script(script)
        • (r) ScriptedUpsert(upsert)
        • (r) Source()
        • (r) String()
        • (r) Type(typ)
        • (r) Upsert(doc)
        • (r) UseEasyJSON(enable)
        • (r) Version(version)
        • (r) VersionType(versionType)
      • type BulkableRequest
      • type CandidateGenerator
      • type CardinalityAggregation
        • NewCardinalityAggregation()
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) PrecisionThreshold(threshold)
        • (a) Rehash(rehash)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type CatAliasesResponse
      • type CatAliasesResponseRow
      • type CatAliasesService
        • NewCatAliasesService(client)
        • (s) Alias(alias)
        • (s) Columns(columns)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Human(human)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Sort(fields)
      • type CatAllocationResponse
      • type CatAllocationResponseRow
      • type CatAllocationService
        • NewCatAllocationService(client)
        • (s) Bytes(bytes)
        • (s) Columns(columns)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Human(human)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) NodeID(nodes)
        • (s) Pretty(pretty)
        • (s) Sort(fields)
      • type CatCountResponse
      • type CatCountResponseRow
      • type CatCountService
        • NewCatCountService(client)
        • (s) Columns(columns)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Human(human)
        • (s) Index(index)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Sort(fields)
      • type CatHealthResponse
      • type CatHealthResponseRow
      • type CatHealthService
        • NewCatHealthService(client)
        • (s) Columns(columns)
        • (s) DisableTimestamping(disable)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Human(human)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Sort(fields)
      • type CatIndicesResponse
      • type CatIndicesResponseRow
      • type CatIndicesService
        • NewCatIndicesService(client)
        • (s) Bytes(bytes)
        • (s) Columns(columns)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Health(healthState)
        • (s) Human(human)
        • (s) Index(index)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) PrimaryOnly(primaryOnly)
        • (s) Sort(fields)
      • type CatShardsResponse
      • type CatShardsResponseRow
      • type CatShardsService
        • NewCatShardsService(client)
        • (s) Bytes(bytes)
        • (s) Columns(columns)
        • (s) Do(ctx)
        • (s) ErrorTrace(errorTrace)
        • (s) FilterPath(filterPath)
        • (s) Header(name, value)
        • (s) Headers(headers)
        • (s) Human(human)
        • (s) Index(index)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Sort(fields)
      • type ChiSquareSignificanceHeuristic
        • NewChiSquareSignificanceHeuristic()
        • (sh) BackgroundIsSuperset(backgroundIsSuperset)
        • (sh) IncludeNegatives(includeNegatives)
        • (sh) Name()
        • (sh) Source()
      • type ChildrenAggregation
        • NewChildrenAggregation()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Type(typ)
      • type ClearScrollResponse
      • type ClearScrollService
        • NewClearScrollService(client)
        • (s) Do(ctx)
        • (s) Pretty(pretty)
        • (s) ScrollId(scrollIds)
        • (s) Validate()
      • type Client
        • NewClient(options)
        • NewClientFromConfig(cfg)
        • NewSimpleClient(options)
        • (c) Alias()
        • (c) Aliases()
        • (c) Bulk()
        • (c) BulkProcessor()
        • (c) CatAliases()
        • (c) CatAllocation()
        • (c) CatCount()
        • (c) CatHealth()
        • (c) CatIndices()
        • (c) CatShards()
        • (c) ClearScroll(scrollIds)
        • (c) CloseIndex(name)
        • (c) ClusterHealth()
        • (c) ClusterState()
        • (c) ClusterStats()
        • (c) Count(indices)
        • (c) CreateIndex(name)
        • (c) Delete()
        • (c) DeleteByQuery(indices)
        • (c) DeleteIndex(indices)
        • (c) DeleteTemplate()
        • (c) ElasticsearchVersion(url)
        • (c) Exists()
        • (c) Explain(index, typ, id)
        • (c) FieldCaps(indices)
        • (c) FieldStats(indices)
        • (c) Flush(indices)
        • (c) Forcemerge(indices)
        • (c) Get()
        • (c) GetFieldMapping()
        • (c) GetMapping()
        • (c) GetTemplate()
        • (c) HasPlugin(name)
        • (c) Index()
        • (c) IndexAnalyze()
        • (c) IndexDeleteTemplate(name)
        • (c) IndexExists(indices)
        • (c) IndexGet(indices)
        • (c) IndexGetSettings(indices)
        • (c) IndexGetTemplate(names)
        • (c) IndexNames()
        • (c) IndexPutSettings(indices)
        • (c) IndexPutTemplate(name)
        • (c) IndexSegments(indices)
        • (c) IndexStats(indices)
        • (c) IndexTemplateExists(name)
        • (c) IngestDeletePipeline(id)
        • (c) IngestGetPipeline(ids)
        • (c) IngestPutPipeline(id)
        • (c) IngestSimulatePipeline()
        • (c) IsRunning()
        • (c) Mget()
        • (c) MultiGet()
        • (c) MultiSearch()
        • (c) MultiTermVectors()
        • (c) NodesInfo()
        • (c) NodesStats()
        • (c) OpenIndex(name)
        • (c) PerformRequest(ctx, method, path, params, body, ignoreErrors)
        • (c) PerformRequestWithContentType(ctx, method, path, params, body, contentType, ignoreErrors)
        • (c) PerformRequestWithOptions(ctx, opt)
        • (c) Ping(url)
        • (c) Plugins()
        • (c) PutMapping()
        • (c) PutTemplate()
        • (c) Refresh(indices)
        • (c) Reindex()
        • (c) RolloverIndex(alias)
        • (c) Scroll(indices)
        • (c) Search(indices)
        • (c) SearchShards(indices)
        • (c) ShrinkIndex(source, target)
        • (c) SnapshotCreate(repository, snapshot)
        • (c) SnapshotCreateRepository(repository)
        • (c) SnapshotDeleteRepository(repositories)
        • (c) SnapshotGetRepository(repositories)
        • (c) SnapshotVerifyRepository(repository)
        • (c) Start()
        • (c) Stop()
        • (c) String()
        • (c) Suggest(indices)
        • (c) TasksCancel()
        • (c) TasksGetTask()
        • (c) TasksList()
        • (c) TermVectors(index, typ)
        • (c) TypeExists()
        • (c) Update()
        • (c) UpdateByQuery(indices)
        • (c) Validate(indices)
        • (c) WaitForGreenStatus(timeout)
        • (c) WaitForStatus(status, timeout)
        • (c) WaitForYellowStatus(timeout)
      • type ClientOptionFunc
        • SetBasicAuth(username, password)
        • SetDecoder(decoder)
        • SetErrorLog(logger)
        • SetGzip(enabled)
        • SetHeaders(headers)
        • SetHealthcheck(enabled)
        • SetHealthcheckInterval(interval)
        • SetHealthcheckTimeout(timeout)
        • SetHealthcheckTimeoutStartup(timeout)
        • SetHttpClient(httpClient)
        • SetInfoLog(logger)
        • SetMaxRetries(maxRetries)
        • SetRequiredPlugins(plugins)
        • SetRetrier(retrier)
        • SetScheme(scheme)
        • SetSendGetBodyAs(httpMethod)
        • SetSniff(enabled)
        • SetSnifferCallback(f)
        • SetSnifferInterval(interval)
        • SetSnifferTimeout(timeout)
        • SetSnifferTimeoutStartup(timeout)
        • SetTraceLog(logger)
        • SetURL(urls)
      • type ClusterHealthResponse
      • type ClusterHealthService
        • NewClusterHealthService(client)
        • (s) Do(ctx)
        • (s) Index(indices)
        • (s) Level(level)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
        • (s) WaitForActiveShards(waitForActiveShards)
        • (s) WaitForGreenStatus()
        • (s) WaitForNoRelocatingShards(waitForNoRelocatingShards)
        • (s) WaitForNodes(waitForNodes)
        • (s) WaitForStatus(waitForStatus)
        • (s) WaitForYellowStatus()
      • type ClusterIndexHealth
      • type ClusterShardHealth
      • type ClusterStateResponse
      • type ClusterStateService
        • NewClusterStateService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) FlatSettings(flatSettings)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) MasterTimeout(masterTimeout)
        • (s) Metric(metrics)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type ClusterStatsIndices
      • type ClusterStatsIndicesCompletion
      • type ClusterStatsIndicesDocs
      • type ClusterStatsIndicesFieldData
      • type ClusterStatsIndicesFilterCache
      • type ClusterStatsIndicesIdCache
      • type ClusterStatsIndicesPercolate
      • type ClusterStatsIndicesSegments
      • type ClusterStatsIndicesShards
      • type ClusterStatsIndicesShardsIndex
      • type ClusterStatsIndicesShardsIndexFloat64MinMax
      • type ClusterStatsIndicesShardsIndexIntMinMax
      • type ClusterStatsIndicesStore
      • type ClusterStatsNodes
      • type ClusterStatsNodesCount
      • type ClusterStatsNodesFsStats
      • type ClusterStatsNodesJvmStats
      • type ClusterStatsNodesJvmStatsMem
      • type ClusterStatsNodesJvmStatsVersion
      • type ClusterStatsNodesOsStats
      • type ClusterStatsNodesOsStatsCPU
      • type ClusterStatsNodesOsStatsMem
      • type ClusterStatsNodesPlugin
      • type ClusterStatsNodesProcessStats
      • type ClusterStatsNodesProcessStatsCPU
      • type ClusterStatsNodesProcessStatsOpenFileDescriptors
      • type ClusterStatsResponse
      • type ClusterStatsService
        • NewClusterStatsService(client)
        • (s) Do(ctx)
        • (s) FlatSettings(flatSettings)
        • (s) Human(human)
        • (s) NodeId(nodeId)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type CollapseBuilder
        • NewCollapseBuilder(field)
        • (b) Field(field)
        • (b) InnerHit(innerHit)
        • (b) MaxConcurrentGroupRequests(max)
        • (b) Source()
      • type CollectorResult
      • type CommonTermsQuery
        • NewCommonTermsQuery(name, text)
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) CutoffFrequency(f)
        • (q) DisableCoord(disableCoord)
        • (q) HighFreq(f)
        • (q) HighFreqMinimumShouldMatch(minShouldMatch)
        • (q) HighFreqOperator(op)
        • (q) LowFreq(f)
        • (q) LowFreqMinimumShouldMatch(minShouldMatch)
        • (q) LowFreqOperator(op)
        • (q) QueryName(queryName)
        • (q) Source()
      • type CompletionSuggester
        • NewCompletionSuggester(name)
        • (q) Analyzer(analyzer)
        • (q) ContextQueries(queries)
        • (q) ContextQuery(query)
        • (q) Field(field)
        • (q) FuzzyOptions(options)
        • (q) Name()
        • (q) Prefix(prefix)
        • (q) PrefixWithEditDistance(prefix, editDistance)
        • (q) PrefixWithOptions(prefix, options)
        • (q) Regex(regex)
        • (q) RegexOptions(options)
        • (q) RegexWithOptions(regex, options)
        • (q) ShardSize(shardSize)
        • (q) Size(size)
        • (q) Source(includeName)
        • (q) Text(text)
      • type ConstantBackoff
        • NewConstantBackoff(interval)
        • (b) Next(retry)
      • type ConstantScoreQuery
        • NewConstantScoreQuery(filter)
        • (q) Boost(boost)
        • (q) Source()
      • type ContextSuggester
        • NewContextSuggester(name)
        • (q) ContextQueries(queries)
        • (q) ContextQuery(query)
        • (q) Field(field)
        • (q) Name()
        • (q) Prefix(prefix)
        • (q) Size(size)
        • (q) Source(includeName)
      • type CountResponse
      • type CountService
        • NewCountService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) AnalyzeWildcard(analyzeWildcard)
        • (s) Analyzer(analyzer)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) DefaultOperator(defaultOperator)
        • (s) Df(df)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) Lenient(lenient)
        • (s) LowercaseExpandedTerms(lowercaseExpandedTerms)
        • (s) MinScore(minScore)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Q(q)
        • (s) Query(query)
        • (s) Routing(routing)
        • (s) TerminateAfter(terminateAfter)
        • (s) Type(typ)
        • (s) Validate()
      • type CumulativeSumAggregation
        • NewCumulativeSumAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type DateHistogramAggregation
        • NewDateHistogramAggregation()
        • (a) ExtendedBounds(min, max)
        • (a) ExtendedBoundsMax(max)
        • (a) ExtendedBoundsMin(min)
        • (a) Field(field)
        • (a) Format(format)
        • (a) Interval(interval)
        • (a) Keyed(keyed)
        • (a) Meta(metaData)
        • (a) MinDocCount(minDocCount)
        • (a) Missing(missing)
        • (a) Offset(offset)
        • (a) Order(order, asc)
        • (a) OrderByAggregation(aggName, asc)
        • (a) OrderByAggregationAndMetric(aggName, metric, asc)
        • (a) OrderByCount(asc)
        • (a) OrderByCountAsc()
        • (a) OrderByCountDesc()
        • (a) OrderByKey(asc)
        • (a) OrderByKeyAsc()
        • (a) OrderByKeyDesc()
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) TimeZone(timeZone)
      • type DateRangeAggregation
        • NewDateRangeAggregation()
        • (a) AddRange(from, to)
        • (a) AddRangeWithKey(key, from, to)
        • (a) AddUnboundedFrom(to)
        • (a) AddUnboundedFromWithKey(key, to)
        • (a) AddUnboundedTo(from)
        • (a) AddUnboundedToWithKey(key, from)
        • (a) Between(from, to)
        • (a) BetweenWithKey(key, from, to)
        • (a) Field(field)
        • (a) Format(format)
        • (a) Gt(from)
        • (a) GtWithKey(key, from)
        • (a) Keyed(keyed)
        • (a) Lt(to)
        • (a) LtWithKey(key, to)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Unmapped(unmapped)
      • type DateRangeAggregationEntry
      • type Decoder
      • type DefaultDecoder
        • (u) Decode(data, v)
      • type DeleteByQueryService
        • NewDeleteByQueryService(client)
        • (s) AbortOnVersionConflict()
        • (s) AllowNoIndices(allow)
        • (s) AnalyzeWildcard(analyzeWildcard)
        • (s) Analyzer(analyzer)
        • (s) Body(body)
        • (s) Conflicts(conflicts)
        • (s) DF(defaultField)
        • (s) DefaultField(defaultField)
        • (s) DefaultOperator(defaultOperator)
        • (s) Do(ctx)
        • (s) DocvalueFields(docvalueFields)
        • (s) ExpandWildcards(expand)
        • (s) Explain(explain)
        • (s) From(from)
        • (s) IgnoreUnavailable(ignore)
        • (s) Index(index)
        • (s) Lenient(lenient)
        • (s) LowercaseExpandedTerms(lowercaseExpandedTerms)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) ProceedOnVersionConflict()
        • (s) Q(query)
        • (s) Query(query)
        • (s) QueryString(query)
        • (s) Refresh(refresh)
        • (s) RequestCache(requestCache)
        • (s) RequestsPerSecond(requestsPerSecond)
        • (s) Routing(routing)
        • (s) Scroll(scroll)
        • (s) ScrollSize(scrollSize)
        • (s) SearchTimeout(searchTimeout)
        • (s) SearchType(searchType)
        • (s) Size(size)
        • (s) Sort(sort)
        • (s) SortByField(field, ascending)
        • (s) Stats(stats)
        • (s) StoredFields(storedFields)
        • (s) SuggestField(suggestField)
        • (s) SuggestMode(suggestMode)
        • (s) SuggestSize(suggestSize)
        • (s) SuggestText(suggestText)
        • (s) TerminateAfter(terminateAfter)
        • (s) Timeout(timeout)
        • (s) TimeoutInMillis(timeoutInMillis)
        • (s) TrackScores(trackScores)
        • (s) Type(typ)
        • (s) Validate()
        • (s) Version(version)
        • (s) WaitForActiveShards(waitForActiveShards)
        • (s) WaitForCompletion(waitForCompletion)
        • (s) XSource(xSource)
        • (s) XSourceExclude(xSourceExclude)
        • (s) XSourceInclude(xSourceInclude)
      • type DeleteResponse
      • type DeleteService
        • NewDeleteService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Index(index)
        • (s) Parent(parent)
        • (s) Pretty(pretty)
        • (s) Refresh(refresh)
        • (s) Routing(routing)
        • (s) Timeout(timeout)
        • (s) Type(typ)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
        • (s) WaitForActiveShards(waitForActiveShards)
      • type DeleteTemplateService
        • NewDeleteTemplateService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
      • type DerivativeAggregation
        • NewDerivativeAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Unit(unit)
      • type DirectCandidateGenerator
        • NewDirectCandidateGenerator(field)
        • (g) Accuracy(accuracy)
        • (g) Field(field)
        • (g) MaxEdits(maxEdits)
        • (g) MaxInspections(maxInspections)
        • (g) MaxTermFreq(maxTermFreq)
        • (g) MinDocFreq(minDocFreq)
        • (g) MinWordLength(minWordLength)
        • (g) PostFilter(postFilter)
        • (g) PreFilter(preFilter)
        • (g) PrefixLength(prefixLength)
        • (g) Size(size)
        • (g) Sort(sort)
        • (g) Source()
        • (g) StringDistance(stringDistance)
        • (g) SuggestMode(suggestMode)
        • (g) Type()
      • type DisMaxQuery
        • NewDisMaxQuery()
        • (q) Boost(boost)
        • (q) Query(queries)
        • (q) QueryName(queryName)
        • (q) Source()
        • (q) TieBreaker(tieBreaker)
      • type DiscoveryNode
      • type DiversifiedSamplerAggregation
        • NewDiversifiedSamplerAggregation()
        • (a) ExecutionHint(hint)
        • (a) Field(field)
        • (a) MaxDocsPerValue(maxDocsPerValue)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) ShardSize(shardSize)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type EWMAMovAvgModel
        • NewEWMAMovAvgModel()
        • (m) Alpha(alpha)
        • (m) Name()
        • (m) Settings()
      • type Error
        • (e) Error()
      • type ErrorDetails
      • type ExistsQuery
        • NewExistsQuery(name)
        • (q) QueryName(queryName)
        • (q) Source()
      • type ExistsService
        • NewExistsService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Index(index)
        • (s) Parent(parent)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Realtime(realtime)
        • (s) Refresh(refresh)
        • (s) Routing(routing)
        • (s) Type(typ)
        • (s) Validate()
      • type ExplainResponse
      • type ExplainService
        • NewExplainService(client)
        • (s) AnalyzeWildcard(analyzeWildcard)
        • (s) Analyzer(analyzer)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) DefaultOperator(defaultOperator)
        • (s) Df(df)
        • (s) Do(ctx)
        • (s) Fields(fields)
        • (s) Id(id)
        • (s) Index(index)
        • (s) Lenient(lenient)
        • (s) LowercaseExpandedTerms(lowercaseExpandedTerms)
        • (s) Parent(parent)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Q(q)
        • (s) Query(query)
        • (s) Routing(routing)
        • (s) Source(source)
        • (s) Type(typ)
        • (s) Validate()
        • (s) XSource(xSource)
        • (s) XSourceExclude(xSourceExclude)
        • (s) XSourceInclude(xSourceInclude)
      • type ExponentialBackoff
        • NewExponentialBackoff(initialTimeout, maxTimeout)
        • (b) Next(retry)
      • type ExponentialDecayFunction
        • NewExponentialDecayFunction()
        • (fn) Decay(decay)
        • (fn) FieldName(fieldName)
        • (fn) GetWeight()
        • (fn) MultiValueMode(mode)
        • (fn) Name()
        • (fn) Offset(offset)
        • (fn) Origin(origin)
        • (fn) Scale(scale)
        • (fn) Source()
        • (fn) Weight(weight)
      • type ExtendedStatsAggregation
        • NewExtendedStatsAggregation()
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type FailedNodeException
      • type FetchSourceContext
        • NewFetchSourceContext(fetchSource)
        • (fsc) Exclude(excludes)
        • (fsc) FetchSource()
        • (fsc) Include(includes)
        • (fsc) Query()
        • (fsc) SetFetchSource(fetchSource)
        • (fsc) Source()
      • type FieldCaps
      • type FieldCapsRequest
      • type FieldCapsResponse
      • type FieldCapsService
        • NewFieldCapsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Fields(fields)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type FieldSort
        • NewFieldSort(fieldName)
        • (s) Asc()
        • (s) Desc()
        • (s) FieldName(fieldName)
        • (s) Missing(missing)
        • (s) NestedFilter(nestedFilter)
        • (s) NestedPath(nestedPath)
        • (s) Order(ascending)
        • (s) SortMode(sortMode)
        • (s) Source()
        • (s) UnmappedType(typ)
      • type FieldStatistics
      • type FieldStats
      • type FieldStatsComparison
      • type FieldStatsConstraints
      • type FieldStatsRequest
      • type FieldStatsResponse
      • type FieldStatsService
        • NewFieldStatsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) ClusterLevel()
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Fields(fields)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) IndicesLevel()
        • (s) Level(level)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type FieldValueFactorFunction
        • NewFieldValueFactorFunction()
        • (fn) Factor(factor)
        • (fn) Field(field)
        • (fn) GetWeight()
        • (fn) Missing(missing)
        • (fn) Modifier(modifier)
        • (fn) Name()
        • (fn) Source()
        • (fn) Weight(weight)
      • type FilterAggregation
        • NewFilterAggregation()
        • (a) Filter(filter)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type FiltersAggregation
        • NewFiltersAggregation()
        • (a) Filter(filter)
        • (a) FilterWithName(name, filter)
        • (a) Filters(filters)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type FunctionScoreQuery
        • NewFunctionScoreQuery()
        • (q) Add(filter, scoreFunc)
        • (q) AddScoreFunc(scoreFunc)
        • (q) Boost(boost)
        • (q) BoostMode(boostMode)
        • (q) Filter(filter)
        • (q) MaxBoost(maxBoost)
        • (q) MinScore(minScore)
        • (q) Query(query)
        • (q) ScoreMode(scoreMode)
        • (q) Source()
      • type Fuzziness
      • type FuzzyCompletionSuggester
        • NewFuzzyCompletionSuggester(name)
        • (q) Analyzer(analyzer)
        • (q) ContextQueries(queries)
        • (q) ContextQuery(query)
        • (q) Field(field)
        • (q) Fuzziness(fuzziness)
        • (q) FuzzyMinLength(minLength)
        • (q) FuzzyPrefixLength(prefixLength)
        • (q) FuzzyTranspositions(fuzzyTranspositions)
        • (q) Name()
        • (q) ShardSize(shardSize)
        • (q) Size(size)
        • (q) Source(includeName)
        • (q) Text(text)
        • (q) UnicodeAware(unicodeAware)
      • type FuzzyCompletionSuggesterOptions
        • NewFuzzyCompletionSuggesterOptions()
        • (o) EditDistance(editDistance)
        • (o) MaxDeterminizedStates(max)
        • (o) MinLength(minLength)
        • (o) PrefixLength(prefixLength)
        • (o) Source()
        • (o) Transpositions(transpositions)
        • (o) UnicodeAware(unicodeAware)
      • type FuzzyQuery
        • NewFuzzyQuery(name, value)
        • (q) Boost(boost)
        • (q) Fuzziness(fuzziness)
        • (q) MaxExpansions(maxExpansions)
        • (q) PrefixLength(prefixLength)
        • (q) QueryName(queryName)
        • (q) Rewrite(rewrite)
        • (q) Source()
        • (q) Transpositions(transpositions)
      • type GNDSignificanceHeuristic
        • NewGNDSignificanceHeuristic()
        • (sh) BackgroundIsSuperset(backgroundIsSuperset)
        • (sh) Name()
        • (sh) Source()
      • type GaussDecayFunction
        • NewGaussDecayFunction()
        • (fn) Decay(decay)
        • (fn) FieldName(fieldName)
        • (fn) GetWeight()
        • (fn) MultiValueMode(mode)
        • (fn) Name()
        • (fn) Offset(offset)
        • (fn) Origin(origin)
        • (fn) Scale(scale)
        • (fn) Source()
        • (fn) Weight(weight)
      • type GeoBoundingBoxQuery
        • NewGeoBoundingBoxQuery(name)
        • (q) BottomLeft(bottom, left)
        • (q) BottomLeftFromGeoPoint(point)
        • (q) BottomRight(bottom, right)
        • (q) BottomRightFromGeoPoint(point)
        • (q) QueryName(queryName)
        • (q) Source()
        • (q) TopLeft(top, left)
        • (q) TopLeftFromGeoPoint(point)
        • (q) TopRight(top, right)
        • (q) TopRightFromGeoPoint(point)
        • (q) Type(typ)
      • type GeoBoundsAggregation
        • NewGeoBoundsAggregation()
        • (a) Field(field)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) WrapLongitude(wrapLongitude)
      • type GeoCentroidAggregation
        • NewGeoCentroidAggregation()
        • (a) Field(field)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type GeoDistanceAggregation
        • NewGeoDistanceAggregation()
        • (a) AddRange(from, to)
        • (a) AddRangeWithKey(key, from, to)
        • (a) AddUnboundedFrom(to)
        • (a) AddUnboundedFromWithKey(key, to)
        • (a) AddUnboundedTo(from)
        • (a) AddUnboundedToWithKey(key, from)
        • (a) Between(from, to)
        • (a) BetweenWithKey(key, from, to)
        • (a) DistanceType(distanceType)
        • (a) Field(field)
        • (a) Meta(metaData)
        • (a) Point(latLon)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Unit(unit)
      • type GeoDistanceQuery
        • NewGeoDistanceQuery(name)
        • (q) Distance(distance)
        • (q) DistanceType(distanceType)
        • (q) GeoHash(geohash)
        • (q) GeoPoint(point)
        • (q) Lat(lat)
        • (q) Lon(lon)
        • (q) OptimizeBbox(optimizeBbox)
        • (q) Point(lat, lon)
        • (q) QueryName(queryName)
        • (q) Source()
      • type GeoDistanceSort
        • NewGeoDistanceSort(fieldName)
        • (s) Asc()
        • (s) Desc()
        • (s) DistanceType(distanceType)
        • (s) FieldName(fieldName)
        • (s) GeoDistance(geoDistance)
        • (s) GeoHashes(geohashes)
        • (s) NestedFilter(nestedFilter)
        • (s) NestedPath(nestedPath)
        • (s) Order(ascending)
        • (s) Point(lat, lon)
        • (s) Points(points)
        • (s) SortMode(sortMode)
        • (s) Source()
        • (s) Unit(unit)
      • type GeoHashGridAggregation
        • NewGeoHashGridAggregation()
        • (a) Field(field)
        • (a) Meta(metaData)
        • (a) Precision(precision)
        • (a) ShardSize(shardSize)
        • (a) Size(size)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type GeoPoint
        • GeoPointFromLatLon(lat, lon)
        • GeoPointFromString(latLon)
        • (pt) Source()
      • type GeoPolygonQuery
        • NewGeoPolygonQuery(name)
        • (q) AddGeoPoint(point)
        • (q) AddPoint(lat, lon)
        • (q) QueryName(queryName)
        • (q) Source()
      • type GetResult
      • type GetService
        • NewGetService(client)
        • (s) Do(ctx)
        • (s) FetchSource(fetchSource)
        • (s) FetchSourceContext(fetchSourceContext)
        • (s) Id(id)
        • (s) IgnoreErrorsOnGeneratedFields(ignore)
        • (s) Index(index)
        • (s) Parent(parent)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Realtime(realtime)
        • (s) Refresh(refresh)
        • (s) Routing(routing)
        • (s) StoredFields(storedFields)
        • (s) Type(typ)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
      • type GetTemplateResponse
      • type GetTemplateService
        • NewGetTemplateService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
      • type GlobalAggregation
        • NewGlobalAggregation()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type HasChildQuery
        • NewHasChildQuery(childType, query)
        • (q) Boost(boost)
        • (q) InnerHit(innerHit)
        • (q) MaxChildren(maxChildren)
        • (q) MinChildren(minChildren)
        • (q) QueryName(queryName)
        • (q) ScoreMode(scoreMode)
        • (q) ShortCircuitCutoff(shortCircuitCutoff)
        • (q) Source()
      • type HasParentQuery
        • NewHasParentQuery(parentType, query)
        • (q) Boost(boost)
        • (q) IgnoreUnmapped(ignore)
        • (q) InnerHit(innerHit)
        • (q) QueryName(queryName)
        • (q) Score(score)
        • (q) Source()
      • type Highlight
        • NewHighlight()
        • (hl) BoundaryChars(boundaryChars)
        • (hl) BoundaryMaxScan(boundaryMaxScan)
        • (hl) BoundaryScannerLocale(boundaryScannerLocale)
        • (hl) BoundaryScannerType(boundaryScannerType)
        • (hl) Encoder(encoder)
        • (hl) Field(name)
        • (hl) Fields(fields)
        • (hl) ForceSource(forceSource)
        • (hl) FragmentSize(fragmentSize)
        • (hl) Fragmenter(fragmenter)
        • (hl) HighlightFilter(highlightFilter)
        • (hl) HighlightQuery(highlightQuery)
        • (hl) HighlighterType(highlighterType)
        • (hl) NoMatchSize(noMatchSize)
        • (hl) NumOfFragments(numOfFragments)
        • (hl) Options(options)
        • (hl) Order(order)
        • (hl) PostTags(postTags)
        • (hl) PreTags(preTags)
        • (hl) RequireFieldMatch(requireFieldMatch)
        • (hl) Source()
        • (hl) TagsSchema(schemaName)
        • (hl) UseExplicitFieldOrder(useExplicitFieldOrder)
      • type HighlighterField
        • NewHighlighterField(name)
        • (f) BoundaryChars(boundaryChars)
        • (f) BoundaryMaxScan(boundaryMaxScan)
        • (f) ForceSource(forceSource)
        • (f) FragmentOffset(fragmentOffset)
        • (f) FragmentSize(fragmentSize)
        • (f) Fragmenter(fragmenter)
        • (f) HighlightFilter(highlightFilter)
        • (f) HighlightQuery(highlightQuery)
        • (f) HighlighterType(highlighterType)
        • (f) MatchedFields(matchedFields)
        • (f) NoMatchSize(noMatchSize)
        • (f) NumOfFragments(numOfFragments)
        • (f) Options(options)
        • (f) Order(order)
        • (f) PhraseLimit(phraseLimit)
        • (f) PostTags(postTags)
        • (f) PreTags(preTags)
        • (f) RequireFieldMatch(requireFieldMatch)
        • (f) Source()
      • type HistogramAggregation
        • NewHistogramAggregation()
        • (a) ExtendedBounds(min, max)
        • (a) ExtendedBoundsMax(max)
        • (a) ExtendedBoundsMin(min)
        • (a) Field(field)
        • (a) Interval(interval)
        • (a) MaxBounds(max)
        • (a) Meta(metaData)
        • (a) MinBounds(min)
        • (a) MinDocCount(minDocCount)
        • (a) Missing(missing)
        • (a) Offset(offset)
        • (a) Order(order, asc)
        • (a) OrderByAggregation(aggName, asc)
        • (a) OrderByAggregationAndMetric(aggName, metric, asc)
        • (a) OrderByCount(asc)
        • (a) OrderByCountAsc()
        • (a) OrderByCountDesc()
        • (a) OrderByKey(asc)
        • (a) OrderByKeyAsc()
        • (a) OrderByKeyDesc()
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type HoltLinearMovAvgModel
        • NewHoltLinearMovAvgModel()
        • (m) Alpha(alpha)
        • (m) Beta(beta)
        • (m) Name()
        • (m) Settings()
      • type HoltWintersMovAvgModel
        • NewHoltWintersMovAvgModel()
        • (m) Alpha(alpha)
        • (m) Beta(beta)
        • (m) Gamma(gamma)
        • (m) Name()
        • (m) Pad(pad)
        • (m) Period(period)
        • (m) SeasonalityType(typ)
        • (m) Settings()
      • type IPRangeAggregation
        • NewIPRangeAggregation()
        • (a) AddMaskRange(mask)
        • (a) AddMaskRangeWithKey(key, mask)
        • (a) AddRange(from, to)
        • (a) AddRangeWithKey(key, from, to)
        • (a) AddUnboundedFrom(to)
        • (a) AddUnboundedFromWithKey(key, to)
        • (a) AddUnboundedTo(from)
        • (a) AddUnboundedToWithKey(key, from)
        • (a) Between(from, to)
        • (a) BetweenWithKey(key, from, to)
        • (a) Field(field)
        • (a) Gt(from)
        • (a) GtWithKey(key, from)
        • (a) Keyed(keyed)
        • (a) Lt(to)
        • (a) LtWithKey(key, to)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type IPRangeAggregationEntry
      • type IdsQuery
        • NewIdsQuery(types)
        • (q) Boost(boost)
        • (q) Ids(ids)
        • (q) QueryName(queryName)
        • (q) Source()
      • type IndexFieldStats
      • type IndexResponse
      • type IndexSegments
      • type IndexSegmentsDetails
      • type IndexSegmentsRamTree
      • type IndexSegmentsRouting
      • type IndexSegmentsShards
      • type IndexService
        • NewIndexService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Index(index)
        • (s) OpType(opType)
        • (s) Parent(parent)
        • (s) Pipeline(pipeline)
        • (s) Pretty(pretty)
        • (s) Refresh(refresh)
        • (s) Routing(routing)
        • (s) TTL(ttl)
        • (s) Timeout(timeout)
        • (s) Timestamp(timestamp)
        • (s) Ttl(ttl)
        • (s) Type(typ)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
        • (s) WaitForActiveShards(waitForActiveShards)
      • type IndexStats
      • type IndexStatsCompletion
      • type IndexStatsDetails
      • type IndexStatsDocs
      • type IndexStatsFielddata
      • type IndexStatsFilterCache
      • type IndexStatsFlush
      • type IndexStatsGet
      • type IndexStatsIdCache
      • type IndexStatsIndexing
      • type IndexStatsMerges
      • type IndexStatsPercolate
      • type IndexStatsQueryCache
      • type IndexStatsRefresh
      • type IndexStatsSearch
      • type IndexStatsSegments
      • type IndexStatsStore
      • type IndexStatsSuggest
      • type IndexStatsTranslog
      • type IndexStatsWarmer
      • type IndicesAnalyzeRequest
      • type IndicesAnalyzeResponse
      • type IndicesAnalyzeResponseDetail
      • type IndicesAnalyzeResponseToken
      • type IndicesAnalyzeService
        • NewIndicesAnalyzeService(client)
        • (s) Analyzer(analyzer)
        • (s) Attributes(attributes)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) CharFilter(charFilter)
        • (s) Do(ctx)
        • (s) Explain(explain)
        • (s) Field(field)
        • (s) Filter(filter)
        • (s) Format(format)
        • (s) Index(index)
        • (s) PreferLocal(preferLocal)
        • (s) Pretty(pretty)
        • (s) Request(request)
        • (s) Text(text)
        • (s) Tokenizer(tokenizer)
        • (s) Validate()
      • type IndicesCloseResponse
      • type IndicesCloseService
        • NewIndicesCloseService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IndicesCreateResult
      • type IndicesCreateService
        • NewIndicesCreateService(client)
        • (b) Body(body)
        • (b) BodyJson(body)
        • (b) BodyString(body)
        • (b) Do(ctx)
        • (b) Index(index)
        • (s) MasterTimeout(masterTimeout)
        • (b) Pretty(pretty)
        • (s) Timeout(timeout)
      • type IndicesDeleteResponse
      • type IndicesDeleteService
        • NewIndicesDeleteService(client)
        • (s) Do(ctx)
        • (s) Index(index)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IndicesDeleteTemplateResponse
      • type IndicesDeleteTemplateService
        • NewIndicesDeleteTemplateService(client)
        • (s) Do(ctx)
        • (s) MasterTimeout(masterTimeout)
        • (s) Name(name)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IndicesExistsService
        • NewIndicesExistsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) Local(local)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesExistsTemplateService
        • NewIndicesExistsTemplateService(client)
        • (s) Do(ctx)
        • (s) Local(local)
        • (s) Name(name)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesExistsTypeService
        • NewIndicesExistsTypeService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) Pretty(pretty)
        • (s) Type(types)
        • (s) Validate()
      • type IndicesFlushResponse
      • type IndicesFlushService
        • NewIndicesFlushService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Force(force)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Pretty(pretty)
        • (s) Validate()
        • (s) WaitIfOngoing(waitIfOngoing)
      • type IndicesForcemergeResponse
      • type IndicesForcemergeService
        • NewIndicesForcemergeService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Flush(flush)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) MaxNumSegments(maxNumSegments)
        • (s) OnlyExpungeDeletes(onlyExpungeDeletes)
        • (s) OperationThreading(operationThreading)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesGetFieldMappingService
        • NewGetFieldMappingService(client)
        • NewIndicesGetFieldMappingService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Field(fields)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) Pretty(pretty)
        • (s) Type(types)
        • (s) Validate()
      • type IndicesGetMappingService
        • NewGetMappingService(client)
        • NewIndicesGetMappingService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) Pretty(pretty)
        • (s) Type(types)
        • (s) Validate()
      • type IndicesGetResponse
      • type IndicesGetService
        • NewIndicesGetService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Feature(features)
        • (s) Human(human)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesGetSettingsResponse
      • type IndicesGetSettingsService
        • NewIndicesGetSettingsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) FlatSettings(flatSettings)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) Local(local)
        • (s) Name(name)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesGetTemplateResponse
      • type IndicesGetTemplateService
        • NewIndicesGetTemplateService(client)
        • (s) Do(ctx)
        • (s) FlatSettings(flatSettings)
        • (s) Local(local)
        • (s) Name(name)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesOpenResponse
      • type IndicesOpenService
        • NewIndicesOpenService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(index)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IndicesPutMappingService
        • NewIndicesPutMappingService(client)
        • NewPutMappingService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) BodyJson(mapping)
        • (s) BodyString(mapping)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Type(typ)
        • (s) UpdateAllTypes(updateAllTypes)
        • (s) Validate()
      • type IndicesPutSettingsResponse
      • type IndicesPutSettingsService
        • NewIndicesPutSettingsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) FlatSettings(flatSettings)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IndicesPutTemplateResponse
      • type IndicesPutTemplateService
        • NewIndicesPutTemplateService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Cause(cause)
        • (s) Create(create)
        • (s) Do(ctx)
        • (s) FlatSettings(flatSettings)
        • (s) MasterTimeout(masterTimeout)
        • (s) Name(name)
        • (s) Order(order)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
        • (s) Version(version)
      • type IndicesQuery
        • NewIndicesQuery(query, indices)
        • (q) NoMatchQuery(query)
        • (q) NoMatchQueryType(typ)
        • (q) QueryName(queryName)
        • (q) Source()
      • type IndicesRolloverResponse
      • type IndicesRolloverService
        • NewIndicesRolloverService(client)
        • (s) AddCondition(name, value)
        • (s) AddMapping(typ, mapping)
        • (s) AddMaxIndexAgeCondition(time)
        • (s) AddMaxIndexDocsCondition(docs)
        • (s) AddSetting(name, value)
        • (s) Alias(alias)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Conditions(conditions)
        • (s) Do(ctx)
        • (s) DryRun(dryRun)
        • (s) Mappings(mappings)
        • (s) MasterTimeout(masterTimeout)
        • (s) NewIndex(newIndex)
        • (s) Pretty(pretty)
        • (s) Settings(settings)
        • (s) Timeout(timeout)
        • (s) Validate()
        • (s) WaitForActiveShards(waitForActiveShards)
      • type IndicesSegmentsResponse
      • type IndicesSegmentsService
        • NewIndicesSegmentsService(client)
        • (s) AllowNoIndices(allowNoIndices)
        • (s) Do(ctx)
        • (s) ExpandWildcards(expandWildcards)
        • (s) Human(human)
        • (s) IgnoreUnavailable(ignoreUnavailable)
        • (s) Index(indices)
        • (s) OperationThreading(operationThreading)
        • (s) Pretty(pretty)
        • (s) Validate()
        • (s) Verbose(verbose)
      • type IndicesShrinkResponse
      • type IndicesShrinkService
        • NewIndicesShrinkService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Source(source)
        • (s) Target(target)
        • (s) Timeout(timeout)
        • (s) Validate()
        • (s) WaitForActiveShards(waitForActiveShards)
      • type IndicesStatsResponse
      • type IndicesStatsService
        • NewIndicesStatsService(client)
        • (s) CompletionFields(completionFields)
        • (s) Do(ctx)
        • (s) FielddataFields(fielddataFields)
        • (s) Fields(fields)
        • (s) Groups(groups)
        • (s) Human(human)
        • (s) Index(indices)
        • (s) Level(level)
        • (s) Metric(metric)
        • (s) Pretty(pretty)
        • (s) Type(types)
        • (s) Validate()
      • type IngestDeletePipelineResponse
      • type IngestDeletePipelineService
        • NewIngestDeletePipelineService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IngestGetPipeline
      • type IngestGetPipelineResponse
      • type IngestGetPipelineService
        • NewIngestGetPipelineService(client)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type IngestPutPipelineResponse
      • type IngestPutPipelineService
        • NewIngestPutPipelineService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) MasterTimeout(masterTimeout)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Validate()
      • type IngestSimulateDocumentResult
      • type IngestSimulatePipelineResponse
      • type IngestSimulatePipelineService
        • NewIngestSimulatePipelineService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) Pretty(pretty)
        • (s) Validate()
        • (s) Verbose(verbose)
      • type IngestSimulateProcessorResult
      • type InnerHit
        • NewInnerHit()
        • (hit) DocvalueField(docvalueField)
        • (hit) DocvalueFields(docvalueFields)
        • (hit) Explain(explain)
        • (hit) FetchSource(fetchSource)
        • (hit) FetchSourceContext(fetchSourceContext)
        • (hit) From(from)
        • (hit) Highlight(highlight)
        • (hit) Highlighter()
        • (hit) Name(name)
        • (hit) NoStoredFields()
        • (hit) Path(path)
        • (hit) Query(query)
        • (hit) ScriptField(scriptField)
        • (hit) ScriptFields(scriptFields)
        • (hit) Size(size)
        • (hit) Sort(field, ascending)
        • (hit) SortBy(sorter)
        • (hit) SortWithInfo(info)
        • (hit) Source()
        • (hit) StoredField(storedFieldName)
        • (hit) StoredFields(storedFieldNames)
        • (hit) TrackScores(trackScores)
        • (hit) Type(typ)
        • (hit) Version(version)
      • type JLHScoreSignificanceHeuristic
        • NewJLHScoreSignificanceHeuristic()
        • (sh) Name()
        • (sh) Source()
      • type LaplaceSmoothingModel
        • NewLaplaceSmoothingModel(alpha)
        • (sm) Source()
        • (sm) Type()
      • type LinearDecayFunction
        • NewLinearDecayFunction()
        • (fn) Decay(decay)
        • (fn) FieldName(fieldName)
        • (fn) GetMultiValueMode()
        • (fn) GetWeight()
        • (fn) MultiValueMode(mode)
        • (fn) Name()
        • (fn) Offset(offset)
        • (fn) Origin(origin)
        • (fn) Scale(scale)
        • (fn) Source()
        • (fn) Weight(weight)
      • type LinearInterpolationSmoothingModel
        • NewLinearInterpolationSmoothingModel(trigramLamda, bigramLambda, unigramLambda)
        • (sm) Source()
        • (sm) Type()
      • type LinearMovAvgModel
        • NewLinearMovAvgModel()
        • (m) Name()
        • (m) Settings()
      • type Logger
      • type MatchAllQuery
        • NewMatchAllQuery()
        • (q) Boost(boost)
        • (q) QueryName(name)
        • (q) Source()
      • type MatchNoneQuery
        • NewMatchNoneQuery()
        • (q) QueryName(name)
        • (q) Source()
      • type MatchPhrasePrefixQuery
        • NewMatchPhrasePrefixQuery(name, value)
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) MaxExpansions(n)
        • (q) QueryName(queryName)
        • (q) Slop(slop)
        • (q) Source()
      • type MatchPhraseQuery
        • NewMatchPhraseQuery(name, value)
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) QueryName(queryName)
        • (q) Slop(slop)
        • (q) Source()
      • type MatchQuery
        • NewMatchQuery(name, text)
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) CutoffFrequency(cutoff)
        • (q) Fuzziness(fuzziness)
        • (q) FuzzyRewrite(fuzzyRewrite)
        • (q) FuzzyTranspositions(fuzzyTranspositions)
        • (q) Lenient(lenient)
        • (q) MaxExpansions(maxExpansions)
        • (q) MinimumShouldMatch(minimumShouldMatch)
        • (q) Operator(operator)
        • (q) PrefixLength(prefixLength)
        • (q) QueryName(queryName)
        • (q) Source()
        • (q) ZeroTermsQuery(zeroTermsQuery)
      • type MatrixStatsAggregation
        • NewMatrixStatsAggregation()
        • (a) Fields(fields)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Missing(missing)
        • (a) Mode(mode)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) ValueType(valueType)
      • type MaxAggregation
        • NewMaxAggregation()
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type MaxBucketAggregation
        • NewMaxBucketAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type MgetResponse
      • type MgetService
        • NewMgetService(client)
        • (s) Add(items)
        • (s) Do(ctx)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Realtime(realtime)
        • (s) Refresh(refresh)
        • (s) Routing(routing)
        • (s) Source()
        • (s) StoredFields(storedFields)
      • type MinAggregation
        • NewMinAggregation()
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type MinBucketAggregation
        • NewMinBucketAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type MissingAggregation
        • NewMissingAggregation()
        • (a) Field(field)
        • (a) Meta(metaData)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type MoreLikeThisQuery
        • NewMoreLikeThisQuery()
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) BoostTerms(boostTerms)
        • (q) FailOnUnsupportedField(fail)
        • (q) Field(fields)
        • (q) Ids(ids)
        • (q) IgnoreLikeItems(ignoreDocs)
        • (q) IgnoreLikeText(ignoreLikeText)
        • (q) Include(include)
        • (q) LikeItems(docs)
        • (q) LikeText(likeTexts)
        • (q) MaxDocFreq(maxDocFreq)
        • (q) MaxQueryTerms(maxQueryTerms)
        • (q) MaxWordLen(maxWordLen)
        • (q) MinDocFreq(minDocFreq)
        • (q) MinTermFreq(minTermFreq)
        • (q) MinWordLen(minWordLen)
        • (q) MinimumShouldMatch(minimumShouldMatch)
        • (q) QueryName(queryName)
        • (q) Source()
        • (q) StopWord(stopWords)
      • type MoreLikeThisQueryItem
        • NewMoreLikeThisQueryItem()
        • (item) Doc(doc)
        • (item) FetchSourceContext(fsc)
        • (item) Fields(fields)
        • (item) Id(id)
        • (item) Index(index)
        • (item) LikeText(likeText)
        • (item) Routing(routing)
        • (item) Source()
        • (item) Type(typ)
        • (item) Version(version)
        • (item) VersionType(versionType)
      • type MovAvgAggregation
        • NewMovAvgAggregation()
        • (a) BucketsPath(bucketsPaths)
        • (a) Format(format)
        • (a) GapInsertZeros()
        • (a) GapPolicy(gapPolicy)
        • (a) GapSkip()
        • (a) Meta(metaData)
        • (a) Minimize(minimize)
        • (a) Model(model)
        • (a) Predict(numPredictions)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Window(window)
      • type MovAvgModel
      • type MultiGetItem
        • NewMultiGetItem()
        • (item) FetchSource(fetchSourceContext)
        • (item) Id(id)
        • (item) Index(index)
        • (item) Routing(routing)
        • (item) Source()
        • (item) StoredFields(storedFields)
        • (item) Type(typ)
        • (item) Version(version)
        • (item) VersionType(versionType)
      • type MultiMatchQuery
        • NewMultiMatchQuery(text, fields)
        • (q) Analyzer(analyzer)
        • (q) Boost(boost)
        • (q) CutoffFrequency(cutoff)
        • (q) Field(field)
        • (q) FieldWithBoost(field, boost)
        • (q) Fuzziness(fuzziness)
        • (q) FuzzyRewrite(fuzzyRewrite)
        • (q) Lenient(lenient)
        • (q) MaxExpansions(maxExpansions)
        • (q) MinimumShouldMatch(minimumShouldMatch)
        • (q) Operator(operator)
        • (q) PrefixLength(prefixLength)
        • (q) QueryName(queryName)
        • (q) Rewrite(rewrite)
        • (q) Slop(slop)
        • (q) Source()
        • (q) TieBreaker(tieBreaker)
        • (q) Type(typ)
        • (q) ZeroTermsQuery(zeroTermsQuery)
      • type MultiSearchResult
      • type MultiSearchService
        • NewMultiSearchService(client)
        • (s) Add(requests)
        • (s) Do(ctx)
        • (s) Index(indices)
        • (s) MaxConcurrentSearches(max)
        • (s) PreFilterShardSize(size)
        • (s) Pretty(pretty)
      • type MultiTermvectorItem
        • NewMultiTermvectorItem()
        • (s) Doc(doc)
        • (s) FieldStatistics(fieldStatistics)
        • (s) Fields(fields)
        • (s) Id(id)
        • (s) Index(index)
        • (s) Offsets(offsets)
        • (s) Parent(parent)
        • (s) Payloads(payloads)
        • (s) PerFieldAnalyzer(perFieldAnalyzer)
        • (s) Positions(positions)
        • (s) Preference(preference)
        • (s) Realtime(realtime)
        • (s) Routing(routing)
        • (s) Source()
        • (s) TermStatistics(termStatistics)
        • (s) Type(typ)
      • type MultiTermvectorResponse
      • type MultiTermvectorService
        • NewMultiTermvectorService(client)
        • (s) Add(docs)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) FieldStatistics(fieldStatistics)
        • (s) Fields(fields)
        • (s) Ids(ids)
        • (s) Index(index)
        • (s) Offsets(offsets)
        • (s) Parent(parent)
        • (s) Payloads(payloads)
        • (s) Positions(positions)
        • (s) Preference(preference)
        • (s) Pretty(pretty)
        • (s) Realtime(realtime)
        • (s) Routing(routing)
        • (s) Source()
        • (s) TermStatistics(termStatistics)
        • (s) Type(typ)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
      • type MutualInformationSignificanceHeuristic
        • NewMutualInformationSignificanceHeuristic()
        • (sh) BackgroundIsSuperset(backgroundIsSuperset)
        • (sh) IncludeNegatives(includeNegatives)
        • (sh) Name()
        • (sh) Source()
      • type NestedAggregation
        • NewNestedAggregation()
        • (a) Meta(metaData)
        • (a) Path(path)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type NestedHit
      • type NestedQuery
        • NewNestedQuery(path, query)
        • (q) Boost(boost)
        • (q) IgnoreUnmapped(value)
        • (q) InnerHit(innerHit)
        • (q) QueryName(queryName)
        • (q) ScoreMode(scoreMode)
        • (q) Source()
      • type NodesInfoNode
      • type NodesInfoNodeHTTP
      • type NodesInfoNodeJVM
      • type NodesInfoNodeNetwork
      • type NodesInfoNodeOS
      • type NodesInfoNodePlugin
      • type NodesInfoNodeProcess
      • type NodesInfoNodeThreadPool
      • type NodesInfoNodeThreadPoolSection
      • type NodesInfoNodeTransport
      • type NodesInfoNodeTransportProfile
      • type NodesInfoResponse
      • type NodesInfoService
        • NewNodesInfoService(client)
        • (s) Do(ctx)
        • (s) FlatSettings(flatSettings)
        • (s) Human(human)
        • (s) Metric(metric)
        • (s) NodeId(nodeId)
        • (s) Pretty(pretty)
        • (s) Validate()
      • type NodesStatsBreaker
      • type NodesStatsCompletionStats
      • type NodesStatsDiscovery
      • type NodesStatsDiscoveryStats
      • type NodesStatsDocsStats
      • type NodesStatsFielddataStats
      • type NodesStatsFlushStats
      • type NodesStatsGetStats
      • type NodesStatsIndex
      • type NodesStatsIndexingStats
      • type NodesStatsIngest
      • type NodesStatsIngestStats
      • type NodesStatsMergeStats
      • type NodesStatsNode
      • type NodesStatsNodeFS
      • type NodesStatsNodeFSEntry
      • type NodesStatsNodeFSIOStats
      • type NodesStatsNodeFSIOStatsEntry
      • type NodesStatsNodeHTTP
      • type NodesStatsNodeJVM
      • type NodesStatsNodeJVMBufferPool
      • type NodesStatsNodeJVMClasses
      • type NodesStatsNodeJVMGC
      • type NodesStatsNodeJVMGCCollector
      • type NodesStatsNodeJVMMem
      • type NodesStatsNodeJVMThreads
      • type NodesStatsNodeOS
      • type NodesStatsNodeOSCPU
      • type NodesStatsNodeOSMem
      • type NodesStatsNodeOSSwap
      • type NodesStatsNodeProcess
      • type NodesStatsNodeThreadPool
      • type NodesStatsNodeTransport
      • type NodesStatsPercolateStats
      • type NodesStatsQueryCacheStats
      • type NodesStatsRecoveryStats
      • type NodesStatsRefreshStats
      • type NodesStatsRequestCacheStats
      • type NodesStatsResponse
      • type NodesStatsScriptStats
      • type NodesStatsSearchStats
      • type NodesStatsSegmentsStats
      • type NodesStatsService
        • NewNodesStatsService(client)
        • (s) CompletionFields(completionFields)
        • (s) Do(ctx)
        • (s) FielddataFields(fielddataFields)
        • (s) Fields(fields)
        • (s) Groups(groups)
        • (s) Human(human)
        • (s) IndexMetric(indexMetric)
        • (s) Level(level)
        • (s) Metric(metric)
        • (s) NodeId(nodeId)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) Types(types)
        • (s) Validate()
      • type NodesStatsStoreStats
      • type NodesStatsSuggestStats
      • type NodesStatsTranslogStats
      • type NodesStatsWarmerStats
      • type Notify
      • type Operation
      • type ParentIdQuery
        • NewParentIdQuery(typ, id)
        • (q) Boost(boost)
        • (q) Id(id)
        • (q) IgnoreUnmapped(ignore)
        • (q) InnerHit(innerHit)
        • (q) QueryName(queryName)
        • (q) Source()
        • (q) Type(typ)
      • type PercentageScoreSignificanceHeuristic
        • NewPercentageScoreSignificanceHeuristic()
        • (sh) Name()
        • (sh) Source()
      • type PercentileRanksAggregation
        • NewPercentileRanksAggregation()
        • (a) Compression(compression)
        • (a) Estimator(estimator)
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
        • (a) Values(values)
      • type PercentilesAggregation
        • NewPercentilesAggregation()
        • (a) Compression(compression)
        • (a) Estimator(estimator)
        • (a) Field(field)
        • (a) Format(format)
        • (a) Meta(metaData)
        • (a) Method(method)
        • (a) NumberOfSignificantValueDigits(digits)
        • (a) Percentiles(percentiles)
        • (a) Script(script)
        • (a) Source()
        • (a) SubAggregation(name, subAggregation)
      • type PercentilesBucketAggregation
        • NewPercentilesBucketAggregation()
        • (p) BucketsPath(bucketsPaths)
        • (p) Format(format)
        • (p) GapInsertZeros()
        • (p) GapPolicy(gapPolicy)
        • (p) GapSkip()
        • (p) Meta(metaData)
        • (p) Percents(percents)
        • (p) Source()
        • (p) SubAggregation(name, subAggregation)
      • type PercolatorQuery
        • NewPercolatorQuery()
        • (q) Document(doc)
        • (q) DocumentType(typ)
        • (q) Field(field)
        • (q) IndexedDocumentId(id)
        • (q) IndexedDocumentIndex(index)
        • (q) IndexedDocumentPreference(preference)
        • (q) IndexedDocumentRouting(routing)
        • (q) IndexedDocumentType(typ)
        • (q) IndexedDocumentVersion(version)
        • (q) Source()
      • type PerformRequestOptions
      • type PhraseSuggester
        • NewPhraseSuggester(name)
        • (q) Analyzer(analyzer)
        • (q) CandidateGenerator(generator)
        • (q) CandidateGenerators(generators)
        • (q) ClearCandidateGenerator()
        • (q) CollateParams(collateParams)
        • (q) CollatePreference(collatePreference)
        • (q) CollatePrune(collatePrune)
        • (q) CollateQuery(collateQuery)
        • (q) Confidence(confidence)
        • (q) ContextQueries(queries)
        • (q) ContextQuery(query)
        • (q) Field(field)
        • (q) ForceUnigrams(forceUnigrams)
        • (q) GramSize(gramSize)
        • (q) Highlight(preTag, postTag)
        • (q) MaxErrors(maxErrors)
        • (q) Name()
        • (q) RealWordErrorLikelihood(realWordErrorLikelihood)
        • (q) Separator(separator)
        • (q) ShardSize(shardSize)
        • (q) Size(size)
        • (q) SmoothingModel(smoothingModel)
        • (q) Source(includeName)
        • (q) Text(text)
        • (q) TokenLimit(tokenLimit)
      • type PingResult
      • type PingService
        • NewPingService(client)
        • (s) Do(ctx)
        • (s) HttpHeadOnly(httpHeadOnly)
        • (s) Pretty(pretty)
        • (s) Timeout(timeout)
        • (s) URL(url)
      • type PrefixQuery
        • NewPrefixQuery(name, prefix)
        • (q) Boost(boost)
        • (q) QueryName(queryName)
        • (q) Rewrite(rewrite)
        • (q) Source()
      • type ProfileResult
      • type PutMappingResponse
      • type PutTemplateService
        • NewPutTemplateService(client)
        • (s) BodyJson(body)
        • (s) BodyString(body)
        • (s) Do(ctx)
        • (s) Id(id)
        • (s) OpType(opType)
        • (s) Validate()
        • (s) Version(version)
        • (s) VersionType(versionType)
      • type Query
      • type QueryProfileShardResult
      • type QueryRescorer
        • NewQueryRescorer(query)
        • (r) Name()
        • (r) QueryWeight(queryWeight)
        • (r) RescoreQueryWeight(rescoreQueryWeight)
        • (r) ScoreMode(scoreMode)
        • (r) Source()
      • type QueryStringQuery
        • NewQueryStringQuery(queryString)
        • (q) AllFields(useAllFields)
        • (q) AllowLeadingWildcard(allowLeadingWildcard)
        • (q) AnalyzeWildcard(analyzeWildcard)
        • (q) Analyzer(analyzer)
        • (q) AutoGeneratePhraseQueries(autoGeneratePhraseQueries)
        • (q) Boost(boost)
        • (q) DefaultField(defaultField)
        • (q) DefaultOperator(operator)
        • (q) EnablePositionIncrements(enablePositionIncrements)
        • (q) Escape(escape)
        • (q) Field(field)
        • (q) FieldWithBoost(field, boost)
        • (q) Fuzziness(fuzziness)
        • (q) FuzzyMaxExpansions(fuzzyMaxExpansions)
        • (q) FuzzyPrefixLength(fuzzyPrefixLength)
        • (q) FuzzyRewrite(fuzzyRewrite)
        • (q) Lenient(lenient)
        • (q) Locale(locale)
        • (q) LowercaseExpandedTerms(lowercaseExpandedTerms)
        • (q) MaxDeterminizedState(maxDeterminizedStates)
        • (q) MinimumShouldMatch(minimumShouldMatch)
        • (q) PhraseSlop(phraseSlop)
        • (q) QueryName(queryName)
        • (q) QuoteAnalyzer(quoteAnalyzer)
        • (q) QuoteFieldSuffix(quoteFieldSuffix)
        • (q) Rewrite(rewrite)
        • (q) Source()