Versions in this module Expand all Collapse all v10006 v10006.1.20 May 22, 2018 Changes in this version + const DefaultGzipEnabled + const DefaultHealthcheckEnabled + const DefaultHealthcheckInterval + const DefaultHealthcheckTimeout + const DefaultHealthcheckTimeoutStartup + const DefaultScheme + const DefaultScrollKeepAlive + const DefaultSendGetBodyAs + const DefaultSnifferEnabled + const DefaultSnifferInterval + const DefaultSnifferTimeout + const DefaultSnifferTimeoutStartup + const DefaultURL + const Version + var ErrNoClient = errors.New("no Elasticsearch node available") + var ErrRetry = errors.New("cannot connect after several retries") + var ErrTimeout = errors.New("timeout") + func IsConflict(err interface{}) bool + func IsConnErr(err error) bool + func IsNotFound(err interface{}) bool + func IsStatusCode(err interface{}, code int) bool + func IsTimeout(err interface{}) bool + func Retry(o Operation, b Backoff) error + func RetryNotify(operation Operation, b Backoff, notify Notify) error + type AcknowledgedResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type AdjacencyMatrixAggregation struct + func NewAdjacencyMatrixAggregation() *AdjacencyMatrixAggregation + func (a *AdjacencyMatrixAggregation) Filters(name string, filter Query) *AdjacencyMatrixAggregation + func (a *AdjacencyMatrixAggregation) Meta(metaData map[string]interface{}) *AdjacencyMatrixAggregation + func (a *AdjacencyMatrixAggregation) Source() (interface{}, error) + func (a *AdjacencyMatrixAggregation) SubAggregation(name string, subAggregation Aggregation) *AdjacencyMatrixAggregation + type Aggregation interface + Source func() (interface{}, error) + type AggregationBucketAdjacencyMatrix struct + Buckets []*AggregationBucketKeyItem + Meta map[string]interface{} + func (a *AggregationBucketAdjacencyMatrix) UnmarshalJSON(data []byte) error + type AggregationBucketCompositeItem struct + DocCount int64 + Key map[string]interface{} + func (a *AggregationBucketCompositeItem) UnmarshalJSON(data []byte) error + type AggregationBucketCompositeItems struct + Buckets []*AggregationBucketCompositeItem + Meta map[string]interface{} + func (a *AggregationBucketCompositeItems) UnmarshalJSON(data []byte) error + type AggregationBucketFilters struct + Buckets []*AggregationBucketKeyItem + Meta map[string]interface{} + NamedBuckets map[string]*AggregationBucketKeyItem + func (a *AggregationBucketFilters) UnmarshalJSON(data []byte) error + type AggregationBucketHistogramItem struct + DocCount int64 + Key float64 + KeyAsString *string + func (a *AggregationBucketHistogramItem) UnmarshalJSON(data []byte) error + type AggregationBucketHistogramItems struct + Buckets []*AggregationBucketHistogramItem + Meta map[string]interface{} + func (a *AggregationBucketHistogramItems) UnmarshalJSON(data []byte) error + type AggregationBucketKeyItem struct + DocCount int64 + Key interface{} + KeyAsString *string + KeyNumber json.Number + func (a *AggregationBucketKeyItem) UnmarshalJSON(data []byte) error + type AggregationBucketKeyItems struct + Buckets []*AggregationBucketKeyItem + DocCountErrorUpperBound int64 + Meta map[string]interface{} + SumOfOtherDocCount int64 + func (a *AggregationBucketKeyItems) UnmarshalJSON(data []byte) error + type AggregationBucketKeyedRangeItems struct + Buckets map[string]*AggregationBucketRangeItem + DocCountErrorUpperBound int64 + Meta map[string]interface{} + SumOfOtherDocCount int64 + func (a *AggregationBucketKeyedRangeItems) UnmarshalJSON(data []byte) error + type AggregationBucketRangeItem struct + DocCount int64 + From *float64 + FromAsString string + Key string + To *float64 + ToAsString string + func (a *AggregationBucketRangeItem) UnmarshalJSON(data []byte) error + type AggregationBucketRangeItems struct + Buckets []*AggregationBucketRangeItem + DocCountErrorUpperBound int64 + Meta map[string]interface{} + SumOfOtherDocCount int64 + func (a *AggregationBucketRangeItems) UnmarshalJSON(data []byte) error + type AggregationBucketSignificantTerm struct + BgCount int64 + DocCount int64 + Key string + Score float64 + func (a *AggregationBucketSignificantTerm) UnmarshalJSON(data []byte) error + type AggregationBucketSignificantTerms struct + Buckets []*AggregationBucketSignificantTerm + DocCount int64 + Meta map[string]interface{} + func (a *AggregationBucketSignificantTerms) UnmarshalJSON(data []byte) error + type AggregationExtendedStatsMetric struct + Avg *float64 + Count int64 + Max *float64 + Meta map[string]interface{} + Min *float64 + StdDeviation *float64 + Sum *float64 + SumOfSquares *float64 + Variance *float64 + func (a *AggregationExtendedStatsMetric) UnmarshalJSON(data []byte) error + type AggregationGeoBoundsMetric struct + Bounds struct{ ... } + Meta map[string]interface{} + func (a *AggregationGeoBoundsMetric) UnmarshalJSON(data []byte) error + type AggregationGeoCentroidMetric struct + Count int + Location struct{ ... } + Meta map[string]interface{} + func (a *AggregationGeoCentroidMetric) UnmarshalJSON(data []byte) error + type AggregationMatrixStats struct + Fields []*AggregationMatrixStatsField + Meta map[string]interface{} + func (a *AggregationMatrixStats) UnmarshalJSON(data []byte) error + type AggregationMatrixStatsField struct + Correlation map[string]float64 + Count int64 + Covariance map[string]float64 + Kurtosis float64 + Mean float64 + Name string + Skewness float64 + Variance float64 + type AggregationPercentilesMetric struct + Meta map[string]interface{} + Values map[string]float64 + func (a *AggregationPercentilesMetric) UnmarshalJSON(data []byte) error + type AggregationPipelineBucketMetricValue struct + Keys []interface{} + Meta map[string]interface{} + Value *float64 + ValueAsString string + func (a *AggregationPipelineBucketMetricValue) UnmarshalJSON(data []byte) error + type AggregationPipelineDerivative struct + Meta map[string]interface{} + NormalizedValue *float64 + NormalizedValueAsString string + Value *float64 + ValueAsString string + func (a *AggregationPipelineDerivative) UnmarshalJSON(data []byte) error + type AggregationPipelinePercentilesMetric struct + Meta map[string]interface{} + Values map[string]float64 + func (a *AggregationPipelinePercentilesMetric) UnmarshalJSON(data []byte) error + type AggregationPipelineSimpleValue struct + Meta map[string]interface{} + Value *float64 + ValueAsString string + func (a *AggregationPipelineSimpleValue) UnmarshalJSON(data []byte) error + type AggregationPipelineStatsMetric struct + Avg *float64 + AvgAsString string + Count int64 + CountAsString string + Max *float64 + MaxAsString string + Meta map[string]interface{} + Min *float64 + MinAsString string + Sum *float64 + SumAsString string + func (a *AggregationPipelineStatsMetric) UnmarshalJSON(data []byte) error + type AggregationSingleBucket struct + DocCount int64 + Meta map[string]interface{} + func (a *AggregationSingleBucket) UnmarshalJSON(data []byte) error + type AggregationStatsMetric struct + Avg *float64 + Count int64 + Max *float64 + Meta map[string]interface{} + Min *float64 + Sum *float64 + func (a *AggregationStatsMetric) UnmarshalJSON(data []byte) error + type AggregationTopHitsMetric struct + Hits *SearchHits + Meta map[string]interface{} + func (a *AggregationTopHitsMetric) UnmarshalJSON(data []byte) error + type AggregationValueMetric struct + Meta map[string]interface{} + Value *float64 + func (a *AggregationValueMetric) UnmarshalJSON(data []byte) error + type Aggregations map[string]*json.RawMessage + func (a Aggregations) AdjacencyMatrix(name string) (*AggregationBucketAdjacencyMatrix, bool) + func (a Aggregations) Avg(name string) (*AggregationValueMetric, bool) + func (a Aggregations) AvgBucket(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) BucketScript(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) Cardinality(name string) (*AggregationValueMetric, bool) + func (a Aggregations) Children(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) Composite(name string) (*AggregationBucketCompositeItems, bool) + func (a Aggregations) CumulativeSum(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) DateHistogram(name string) (*AggregationBucketHistogramItems, bool) + func (a Aggregations) DateRange(name string) (*AggregationBucketRangeItems, bool) + func (a Aggregations) Derivative(name string) (*AggregationPipelineDerivative, bool) + func (a Aggregations) DiversifiedSampler(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) ExtendedStats(name string) (*AggregationExtendedStatsMetric, bool) + func (a Aggregations) Filter(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) Filters(name string) (*AggregationBucketFilters, bool) + func (a Aggregations) GeoBounds(name string) (*AggregationGeoBoundsMetric, bool) + func (a Aggregations) GeoCentroid(name string) (*AggregationGeoCentroidMetric, bool) + func (a Aggregations) GeoDistance(name string) (*AggregationBucketRangeItems, bool) + func (a Aggregations) GeoHash(name string) (*AggregationBucketKeyItems, bool) + func (a Aggregations) Global(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) Histogram(name string) (*AggregationBucketHistogramItems, bool) + func (a Aggregations) IPRange(name string) (*AggregationBucketRangeItems, bool) + func (a Aggregations) KeyedRange(name string) (*AggregationBucketKeyedRangeItems, bool) + func (a Aggregations) MatrixStats(name string) (*AggregationMatrixStats, bool) + func (a Aggregations) Max(name string) (*AggregationValueMetric, bool) + func (a Aggregations) MaxBucket(name string) (*AggregationPipelineBucketMetricValue, bool) + func (a Aggregations) Min(name string) (*AggregationValueMetric, bool) + func (a Aggregations) MinBucket(name string) (*AggregationPipelineBucketMetricValue, bool) + func (a Aggregations) Missing(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) MovAvg(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) Nested(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) PercentileRanks(name string) (*AggregationPercentilesMetric, bool) + func (a Aggregations) Percentiles(name string) (*AggregationPercentilesMetric, bool) + func (a Aggregations) PercentilesBucket(name string) (*AggregationPipelinePercentilesMetric, bool) + func (a Aggregations) Range(name string) (*AggregationBucketRangeItems, bool) + func (a Aggregations) ReverseNested(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) Sampler(name string) (*AggregationSingleBucket, bool) + func (a Aggregations) SerialDiff(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) SignificantTerms(name string) (*AggregationBucketSignificantTerms, bool) + func (a Aggregations) Stats(name string) (*AggregationStatsMetric, bool) + func (a Aggregations) StatsBucket(name string) (*AggregationPipelineStatsMetric, bool) + func (a Aggregations) Sum(name string) (*AggregationValueMetric, bool) + func (a Aggregations) SumBucket(name string) (*AggregationPipelineSimpleValue, bool) + func (a Aggregations) Terms(name string) (*AggregationBucketKeyItems, bool) + func (a Aggregations) TopHits(name string) (*AggregationTopHitsMetric, bool) + func (a Aggregations) ValueCount(name string) (*AggregationValueMetric, bool) + type AliasAction interface + Source func() (interface{}, error) + type AliasAddAction struct + func NewAliasAddAction(alias string) *AliasAddAction + func (a *AliasAddAction) Filter(filter Query) *AliasAddAction + func (a *AliasAddAction) Index(index ...string) *AliasAddAction + func (a *AliasAddAction) IndexRouting(routing string) *AliasAddAction + func (a *AliasAddAction) Routing(routing string) *AliasAddAction + func (a *AliasAddAction) SearchRouting(routing ...string) *AliasAddAction + func (a *AliasAddAction) Source() (interface{}, error) + func (a *AliasAddAction) Validate() error + type AliasRemoveAction struct + func NewAliasRemoveAction(alias string) *AliasRemoveAction + func (a *AliasRemoveAction) Index(index ...string) *AliasRemoveAction + func (a *AliasRemoveAction) Source() (interface{}, error) + func (a *AliasRemoveAction) Validate() error + type AliasRemoveIndexAction struct + func NewAliasRemoveIndexAction(index string) *AliasRemoveIndexAction + func (a *AliasRemoveIndexAction) Source() (interface{}, error) + func (a *AliasRemoveIndexAction) Validate() error + type AliasResult struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type AliasService struct + func NewAliasService(client *Client) *AliasService + func (s *AliasService) Action(action ...AliasAction) *AliasService + func (s *AliasService) Add(indexName string, aliasName string) *AliasService + func (s *AliasService) AddWithFilter(indexName string, aliasName string, filter Query) *AliasService + func (s *AliasService) Do(ctx context.Context) (*AliasResult, error) + func (s *AliasService) Pretty(pretty bool) *AliasService + func (s *AliasService) Remove(indexName string, aliasName string) *AliasService + type AliasesResult struct + Indices map[string]indexResult + func (ar AliasesResult) IndicesByAlias(aliasName string) []string + type AliasesService struct + func NewAliasesService(client *Client) *AliasesService + func (s *AliasesService) Alias(alias ...string) *AliasesService + func (s *AliasesService) Do(ctx context.Context) (*AliasesResult, error) + func (s *AliasesService) Index(index ...string) *AliasesService + func (s *AliasesService) Pretty(pretty bool) *AliasesService + type AvgAggregation struct + func NewAvgAggregation() *AvgAggregation + func (a *AvgAggregation) Field(field string) *AvgAggregation + func (a *AvgAggregation) Format(format string) *AvgAggregation + func (a *AvgAggregation) Meta(metaData map[string]interface{}) *AvgAggregation + func (a *AvgAggregation) Script(script *Script) *AvgAggregation + func (a *AvgAggregation) Source() (interface{}, error) + func (a *AvgAggregation) SubAggregation(name string, subAggregation Aggregation) *AvgAggregation + type AvgBucketAggregation struct + func NewAvgBucketAggregation() *AvgBucketAggregation + func (a *AvgBucketAggregation) BucketsPath(bucketsPaths ...string) *AvgBucketAggregation + func (a *AvgBucketAggregation) Format(format string) *AvgBucketAggregation + func (a *AvgBucketAggregation) GapInsertZeros() *AvgBucketAggregation + func (a *AvgBucketAggregation) GapPolicy(gapPolicy string) *AvgBucketAggregation + func (a *AvgBucketAggregation) GapSkip() *AvgBucketAggregation + func (a *AvgBucketAggregation) Meta(metaData map[string]interface{}) *AvgBucketAggregation + func (a *AvgBucketAggregation) Source() (interface{}, error) + type Backoff interface + Next func(retry int) (time.Duration, bool) + type BackoffFunc func(retry int) (time.Duration, bool) + type BackoffRetrier struct + func NewBackoffRetrier(backoff Backoff) *BackoffRetrier + func (r *BackoffRetrier) Retry(ctx context.Context, retry int, req *http.Request, resp *http.Response, ...) (time.Duration, bool, error) + type BoolQuery struct + func NewBoolQuery() *BoolQuery + func (q *BoolQuery) AdjustPureNegative(adjustPureNegative bool) *BoolQuery + func (q *BoolQuery) Boost(boost float64) *BoolQuery + func (q *BoolQuery) Filter(filters ...Query) *BoolQuery + func (q *BoolQuery) MinimumNumberShouldMatch(minimumNumberShouldMatch int) *BoolQuery + func (q *BoolQuery) MinimumShouldMatch(minimumShouldMatch string) *BoolQuery + func (q *BoolQuery) Must(queries ...Query) *BoolQuery + func (q *BoolQuery) MustNot(queries ...Query) *BoolQuery + func (q *BoolQuery) QueryName(queryName string) *BoolQuery + func (q *BoolQuery) Should(queries ...Query) *BoolQuery + func (q *BoolQuery) Source() (interface{}, error) + type BoostingQuery struct + func NewBoostingQuery() *BoostingQuery + func (q *BoostingQuery) Boost(boost float64) *BoostingQuery + func (q *BoostingQuery) Negative(negative Query) *BoostingQuery + func (q *BoostingQuery) NegativeBoost(negativeBoost float64) *BoostingQuery + func (q *BoostingQuery) Positive(positive Query) *BoostingQuery + func (q *BoostingQuery) Source() (interface{}, error) + type BucketCountThresholds struct + MinDocCount *int64 + RequiredSize *int + ShardMinDocCount *int64 + ShardSize *int + type BucketScriptAggregation struct + func NewBucketScriptAggregation() *BucketScriptAggregation + func (a *BucketScriptAggregation) AddBucketsPath(name, path string) *BucketScriptAggregation + func (a *BucketScriptAggregation) BucketsPathsMap(bucketsPathsMap map[string]string) *BucketScriptAggregation + func (a *BucketScriptAggregation) Format(format string) *BucketScriptAggregation + func (a *BucketScriptAggregation) GapInsertZeros() *BucketScriptAggregation + func (a *BucketScriptAggregation) GapPolicy(gapPolicy string) *BucketScriptAggregation + func (a *BucketScriptAggregation) GapSkip() *BucketScriptAggregation + func (a *BucketScriptAggregation) Meta(metaData map[string]interface{}) *BucketScriptAggregation + func (a *BucketScriptAggregation) Script(script *Script) *BucketScriptAggregation + func (a *BucketScriptAggregation) Source() (interface{}, error) + type BucketSelectorAggregation struct + func NewBucketSelectorAggregation() *BucketSelectorAggregation + func (a *BucketSelectorAggregation) AddBucketsPath(name, path string) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) BucketsPathsMap(bucketsPathsMap map[string]string) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) Format(format string) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) GapInsertZeros() *BucketSelectorAggregation + func (a *BucketSelectorAggregation) GapPolicy(gapPolicy string) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) GapSkip() *BucketSelectorAggregation + func (a *BucketSelectorAggregation) Meta(metaData map[string]interface{}) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) Script(script *Script) *BucketSelectorAggregation + func (a *BucketSelectorAggregation) Source() (interface{}, error) + type BucketSortAggregation struct + func NewBucketSortAggregation() *BucketSortAggregation + func (a *BucketSortAggregation) From(from int) *BucketSortAggregation + func (a *BucketSortAggregation) GapInsertZeros() *BucketSortAggregation + func (a *BucketSortAggregation) GapPolicy(gapPolicy string) *BucketSortAggregation + func (a *BucketSortAggregation) GapSkip() *BucketSortAggregation + func (a *BucketSortAggregation) Meta(meta map[string]interface{}) *BucketSortAggregation + func (a *BucketSortAggregation) Size(size int) *BucketSortAggregation + func (a *BucketSortAggregation) Sort(field string, ascending bool) *BucketSortAggregation + func (a *BucketSortAggregation) SortWithInfo(info SortInfo) *BucketSortAggregation + func (a *BucketSortAggregation) Source() (interface{}, error) + type BulkAfterFunc func(executionId int64, requests []BulkableRequest, response *BulkResponse, ...) + type BulkBeforeFunc func(executionId int64, requests []BulkableRequest) + type BulkDeleteRequest struct + func NewBulkDeleteRequest() *BulkDeleteRequest + func (r *BulkDeleteRequest) Id(id string) *BulkDeleteRequest + func (r *BulkDeleteRequest) Index(index string) *BulkDeleteRequest + func (r *BulkDeleteRequest) Parent(parent string) *BulkDeleteRequest + func (r *BulkDeleteRequest) Routing(routing string) *BulkDeleteRequest + func (r *BulkDeleteRequest) Source() ([]string, error) + func (r *BulkDeleteRequest) String() string + func (r *BulkDeleteRequest) Type(typ string) *BulkDeleteRequest + func (r *BulkDeleteRequest) UseEasyJSON(enable bool) *BulkDeleteRequest + func (r *BulkDeleteRequest) Version(version int64) *BulkDeleteRequest + func (r *BulkDeleteRequest) VersionType(versionType string) *BulkDeleteRequest + type BulkIndexByScrollResponse struct + Batches int64 + Canceled string + Created int64 + Deleted int64 + Failures []bulkIndexByScrollResponseFailure + Noops int64 + RequestsPerSecond float64 + Retries struct{ ... } + SliceId *int64 + Throttled string + ThrottledMillis int64 + ThrottledUntil string + ThrottledUntilMillis int64 + TimedOut bool + Took int64 + Total int64 + Updated int64 + VersionConflicts int64 + type BulkIndexRequest struct + func NewBulkIndexRequest() *BulkIndexRequest + func (r *BulkIndexRequest) Doc(doc interface{}) *BulkIndexRequest + func (r *BulkIndexRequest) Id(id string) *BulkIndexRequest + func (r *BulkIndexRequest) Index(index string) *BulkIndexRequest + func (r *BulkIndexRequest) OpType(opType string) *BulkIndexRequest + func (r *BulkIndexRequest) Parent(parent string) *BulkIndexRequest + func (r *BulkIndexRequest) Pipeline(pipeline string) *BulkIndexRequest + func (r *BulkIndexRequest) RetryOnConflict(retryOnConflict int) *BulkIndexRequest + func (r *BulkIndexRequest) Routing(routing string) *BulkIndexRequest + func (r *BulkIndexRequest) Source() ([]string, error) + func (r *BulkIndexRequest) String() string + func (r *BulkIndexRequest) Type(typ string) *BulkIndexRequest + func (r *BulkIndexRequest) UseEasyJSON(enable bool) *BulkIndexRequest + func (r *BulkIndexRequest) Version(version int64) *BulkIndexRequest + func (r *BulkIndexRequest) VersionType(versionType string) *BulkIndexRequest + type BulkProcessor struct + func (p *BulkProcessor) Add(request BulkableRequest) + func (p *BulkProcessor) Close() error + func (p *BulkProcessor) Flush() error + func (p *BulkProcessor) Start(ctx context.Context) error + func (p *BulkProcessor) Stats() BulkProcessorStats + func (p *BulkProcessor) Stop() error + type BulkProcessorService struct + func NewBulkProcessorService(client *Client) *BulkProcessorService + func (s *BulkProcessorService) After(fn BulkAfterFunc) *BulkProcessorService + func (s *BulkProcessorService) Backoff(backoff Backoff) *BulkProcessorService + func (s *BulkProcessorService) Before(fn BulkBeforeFunc) *BulkProcessorService + func (s *BulkProcessorService) BulkActions(bulkActions int) *BulkProcessorService + func (s *BulkProcessorService) BulkSize(bulkSize int) *BulkProcessorService + func (s *BulkProcessorService) Do(ctx context.Context) (*BulkProcessor, error) + func (s *BulkProcessorService) FlushInterval(interval time.Duration) *BulkProcessorService + func (s *BulkProcessorService) Name(name string) *BulkProcessorService + func (s *BulkProcessorService) Stats(wantStats bool) *BulkProcessorService + func (s *BulkProcessorService) Workers(num int) *BulkProcessorService + type BulkProcessorStats struct + Committed int64 + Created int64 + Deleted int64 + Failed int64 + Flushed int64 + Indexed int64 + Succeeded int64 + Updated int64 + Workers []*BulkProcessorWorkerStats + type BulkProcessorWorkerStats struct + LastDuration time.Duration + Queued int64 + type BulkResponse struct + Errors bool + Items []map[string]*BulkResponseItem + Took int + func (r *BulkResponse) ByAction(action string) []*BulkResponseItem + func (r *BulkResponse) ById(id string) []*BulkResponseItem + func (r *BulkResponse) Created() []*BulkResponseItem + func (r *BulkResponse) Deleted() []*BulkResponseItem + func (r *BulkResponse) Failed() []*BulkResponseItem + func (r *BulkResponse) Indexed() []*BulkResponseItem + func (r *BulkResponse) Succeeded() []*BulkResponseItem + func (r *BulkResponse) Updated() []*BulkResponseItem + type BulkResponseItem struct + Error *ErrorDetails + ForcedRefresh bool + GetResult *GetResult + Id string + Index string + PrimaryTerm int64 + Result string + SeqNo int64 + Shards *shardsInfo + Status int + Type string + Version int64 + type BulkService struct + func NewBulkService(client *Client) *BulkService + func (s *BulkService) Add(requests ...BulkableRequest) *BulkService + func (s *BulkService) Do(ctx context.Context) (*BulkResponse, error) + func (s *BulkService) EstimatedSizeInBytes() int64 + func (s *BulkService) Index(index string) *BulkService + func (s *BulkService) NumberOfActions() int + func (s *BulkService) Pipeline(pipeline string) *BulkService + func (s *BulkService) Pretty(pretty bool) *BulkService + func (s *BulkService) Refresh(refresh string) *BulkService + func (s *BulkService) Reset() + func (s *BulkService) Retrier(retrier Retrier) *BulkService + func (s *BulkService) Routing(routing string) *BulkService + func (s *BulkService) Timeout(timeout string) *BulkService + func (s *BulkService) Type(typ string) *BulkService + func (s *BulkService) WaitForActiveShards(waitForActiveShards string) *BulkService + type BulkUpdateRequest struct + func NewBulkUpdateRequest() *BulkUpdateRequest + func (r *BulkUpdateRequest) DetectNoop(detectNoop bool) *BulkUpdateRequest + func (r *BulkUpdateRequest) Doc(doc interface{}) *BulkUpdateRequest + func (r *BulkUpdateRequest) DocAsUpsert(docAsUpsert bool) *BulkUpdateRequest + func (r *BulkUpdateRequest) Id(id string) *BulkUpdateRequest + func (r *BulkUpdateRequest) Index(index string) *BulkUpdateRequest + func (r *BulkUpdateRequest) Parent(parent string) *BulkUpdateRequest + func (r *BulkUpdateRequest) RetryOnConflict(retryOnConflict int) *BulkUpdateRequest + func (r *BulkUpdateRequest) ReturnSource(source bool) *BulkUpdateRequest + func (r *BulkUpdateRequest) Routing(routing string) *BulkUpdateRequest + func (r *BulkUpdateRequest) Script(script *Script) *BulkUpdateRequest + func (r *BulkUpdateRequest) ScriptedUpsert(upsert bool) *BulkUpdateRequest + func (r *BulkUpdateRequest) Source() ([]string, error) + func (r *BulkUpdateRequest) String() string + func (r *BulkUpdateRequest) Type(typ string) *BulkUpdateRequest + func (r *BulkUpdateRequest) Upsert(doc interface{}) *BulkUpdateRequest + func (r *BulkUpdateRequest) UseEasyJSON(enable bool) *BulkUpdateRequest + func (r *BulkUpdateRequest) Version(version int64) *BulkUpdateRequest + func (r *BulkUpdateRequest) VersionType(versionType string) *BulkUpdateRequest + type BulkableRequest interface + Source func() ([]string, error) + type CandidateGenerator interface + Source func() (interface{}, error) + Type func() string + type CardinalityAggregation struct + func NewCardinalityAggregation() *CardinalityAggregation + func (a *CardinalityAggregation) Field(field string) *CardinalityAggregation + func (a *CardinalityAggregation) Format(format string) *CardinalityAggregation + func (a *CardinalityAggregation) Meta(metaData map[string]interface{}) *CardinalityAggregation + func (a *CardinalityAggregation) PrecisionThreshold(threshold int64) *CardinalityAggregation + func (a *CardinalityAggregation) Rehash(rehash bool) *CardinalityAggregation + func (a *CardinalityAggregation) Script(script *Script) *CardinalityAggregation + func (a *CardinalityAggregation) Source() (interface{}, error) + func (a *CardinalityAggregation) SubAggregation(name string, subAggregation Aggregation) *CardinalityAggregation + type ChiSquareSignificanceHeuristic struct + func NewChiSquareSignificanceHeuristic() *ChiSquareSignificanceHeuristic + func (sh *ChiSquareSignificanceHeuristic) BackgroundIsSuperset(backgroundIsSuperset bool) *ChiSquareSignificanceHeuristic + func (sh *ChiSquareSignificanceHeuristic) IncludeNegatives(includeNegatives bool) *ChiSquareSignificanceHeuristic + func (sh *ChiSquareSignificanceHeuristic) Name() string + func (sh *ChiSquareSignificanceHeuristic) Source() (interface{}, error) + type ChildrenAggregation struct + func NewChildrenAggregation() *ChildrenAggregation + func (a *ChildrenAggregation) Meta(metaData map[string]interface{}) *ChildrenAggregation + func (a *ChildrenAggregation) Source() (interface{}, error) + func (a *ChildrenAggregation) SubAggregation(name string, subAggregation Aggregation) *ChildrenAggregation + func (a *ChildrenAggregation) Type(typ string) *ChildrenAggregation + type ClearScrollResponse struct + type ClearScrollService struct + func NewClearScrollService(client *Client) *ClearScrollService + func (s *ClearScrollService) Do(ctx context.Context) (*ClearScrollResponse, error) + func (s *ClearScrollService) Pretty(pretty bool) *ClearScrollService + func (s *ClearScrollService) ScrollId(scrollIds ...string) *ClearScrollService + func (s *ClearScrollService) Validate() error + type Client struct + func NewClient(ctx context.Context, options ...ClientOptionFunc) (*Client, error) + func NewClientFromConfig(ctx context.Context, cfg *config.Config) (*Client, error) + func NewSimpleClient(options ...ClientOptionFunc) (*Client, error) + func (c *Client) Alias() *AliasService + func (c *Client) Aliases() *AliasesService + func (c *Client) Bulk() *BulkService + func (c *Client) BulkProcessor() *BulkProcessorService + func (c *Client) ClearScroll(scrollIds ...string) *ClearScrollService + func (c *Client) CloseIndex(name string) *IndicesCloseService + func (c *Client) ClusterHealth() *ClusterHealthService + func (c *Client) ClusterState() *ClusterStateService + func (c *Client) ClusterStats() *ClusterStatsService + func (c *Client) Count(indices ...string) *CountService + func (c *Client) CreateIndex(name string) *IndicesCreateService + func (c *Client) Delete() *DeleteService + func (c *Client) DeleteByQuery(indices ...string) *DeleteByQueryService + func (c *Client) DeleteIndex(indices ...string) *IndicesDeleteService + func (c *Client) ElasticsearchVersion(url string) (string, error) + func (c *Client) Exists() *ExistsService + func (c *Client) Explain(index, typ, id string) *ExplainService + func (c *Client) FieldCaps(indices ...string) *FieldCapsService + func (c *Client) Flush(indices ...string) *IndicesFlushService + func (c *Client) Forcemerge(indices ...string) *IndicesForcemergeService + func (c *Client) Get() *GetService + func (c *Client) GetFieldMapping() *IndicesGetFieldMappingService + func (c *Client) GetMapping() *IndicesGetMappingService + func (c *Client) HasPlugin(name string) (bool, error) + func (c *Client) Index() *IndexService + func (c *Client) IndexAnalyze() *IndicesAnalyzeService + func (c *Client) IndexDeleteTemplate(name string) *IndicesDeleteTemplateService + func (c *Client) IndexExists(indices ...string) *IndicesExistsService + func (c *Client) IndexGet(indices ...string) *IndicesGetService + func (c *Client) IndexGetSettings(indices ...string) *IndicesGetSettingsService + func (c *Client) IndexGetTemplate(names ...string) *IndicesGetTemplateService + func (c *Client) IndexNames() ([]string, error) + func (c *Client) IndexPutSettings(indices ...string) *IndicesPutSettingsService + func (c *Client) IndexPutTemplate(name string) *IndicesPutTemplateService + func (c *Client) IndexSegments(indices ...string) *IndicesSegmentsService + func (c *Client) IndexStats(indices ...string) *IndicesStatsService + func (c *Client) IndexTemplateExists(name string) *IndicesExistsTemplateService + func (c *Client) IngestDeletePipeline(id string) *IngestDeletePipelineService + func (c *Client) IngestGetPipeline(ids ...string) *IngestGetPipelineService + func (c *Client) IngestPutPipeline(id string) *IngestPutPipelineService + func (c *Client) IngestSimulatePipeline() *IngestSimulatePipelineService + func (c *Client) IsRunning() bool + func (c *Client) Mget() *MgetService + func (c *Client) MultiGet() *MgetService + func (c *Client) MultiSearch() *MultiSearchService + func (c *Client) MultiTermVectors() *MultiTermvectorService + func (c *Client) NodesInfo() *NodesInfoService + func (c *Client) NodesStats() *NodesStatsService + func (c *Client) OpenIndex(name string) *IndicesOpenService + func (c *Client) PerformRequest(ctx context.Context, opt PerformRequestOptions) (*Response, error) + func (c *Client) Ping(url string) *PingService + func (c *Client) Plugins() ([]string, error) + func (c *Client) PutMapping() *IndicesPutMappingService + func (c *Client) Refresh(indices ...string) *RefreshService + func (c *Client) Reindex() *ReindexService + func (c *Client) RolloverIndex(alias string) *IndicesRolloverService + func (c *Client) Scroll(indices ...string) *ScrollService + func (c *Client) Search(indices ...string) *SearchService + func (c *Client) SearchShards(indices ...string) *SearchShardsService + func (c *Client) ShrinkIndex(source, target string) *IndicesShrinkService + func (c *Client) SnapshotCreate(repository string, snapshot string) *SnapshotCreateService + func (c *Client) SnapshotCreateRepository(repository string) *SnapshotCreateRepositoryService + func (c *Client) SnapshotDeleteRepository(repositories ...string) *SnapshotDeleteRepositoryService + func (c *Client) SnapshotGetRepository(repositories ...string) *SnapshotGetRepositoryService + func (c *Client) SnapshotVerifyRepository(repository string) *SnapshotVerifyRepositoryService + func (c *Client) Start(ctx context.Context) + func (c *Client) Stop(ctx context.Context) + func (c *Client) String() string + func (c *Client) TasksCancel() *TasksCancelService + func (c *Client) TasksGetTask() *TasksGetTaskService + func (c *Client) TasksList() *TasksListService + func (c *Client) TermVectors(index, typ string) *TermvectorsService + func (c *Client) TypeExists() *IndicesExistsTypeService + func (c *Client) Update() *UpdateService + func (c *Client) UpdateByQuery(indices ...string) *UpdateByQueryService + func (c *Client) Validate(indices ...string) *ValidateService + func (c *Client) WaitForGreenStatus(timeout string) error + func (c *Client) WaitForStatus(status string, timeout string) error + func (c *Client) WaitForYellowStatus(timeout string) error + type ClientOptionFunc func(*Client) error + func SetBasicAuth(username, password string) ClientOptionFunc + func SetDecoder(decoder Decoder) ClientOptionFunc + func SetErrorLog(logger Logger) ClientOptionFunc + func SetGzip(enabled bool) ClientOptionFunc + func SetHealthcheck(enabled bool) ClientOptionFunc + func SetHealthcheckInterval(interval time.Duration) ClientOptionFunc + func SetHealthcheckTimeout(timeout time.Duration) ClientOptionFunc + func SetHealthcheckTimeoutStartup(timeout time.Duration) ClientOptionFunc + func SetHttpClient(httpClient *http.Client) ClientOptionFunc + func SetInfoLog(logger Logger) ClientOptionFunc + func SetMaxRetries(maxRetries int) ClientOptionFunc + func SetRequestPreprocessor(processor RequestProcessor) ClientOptionFunc + func SetRequiredPlugins(plugins ...string) ClientOptionFunc + func SetRetrier(retrier Retrier) ClientOptionFunc + func SetScheme(scheme string) ClientOptionFunc + func SetSendGetBodyAs(httpMethod string) ClientOptionFunc + func SetSniff(enabled bool) ClientOptionFunc + func SetSnifferCallback(f SnifferCallback) ClientOptionFunc + func SetSnifferInterval(interval time.Duration) ClientOptionFunc + func SetSnifferTimeout(timeout time.Duration) ClientOptionFunc + func SetSnifferTimeoutStartup(timeout time.Duration) ClientOptionFunc + func SetTraceLog(logger Logger) ClientOptionFunc + func SetURL(urls ...string) ClientOptionFunc + type ClusterHealthResponse struct + ActivePrimaryShards int + ActiveShards int + ActiveShardsPercentAsNumber float64 + ClusterName string + DelayedUnassignedShards int + Indices map[string]*ClusterIndexHealth + InitializingShards int + NumberOfDataNodes int + NumberOfInFlightFetch int + NumberOfNodes int + NumberOfPendingTasks int + RelocatingShards int + Status string + TaskMaxWaitTimeInQueueInMillis int + TimedOut bool + UnassignedShards int + ValidationFailures []map[string][]string + type ClusterHealthService struct + func NewClusterHealthService(client *Client) *ClusterHealthService + func (s *ClusterHealthService) Do(ctx context.Context) (*ClusterHealthResponse, error) + func (s *ClusterHealthService) Index(indices ...string) *ClusterHealthService + func (s *ClusterHealthService) Level(level string) *ClusterHealthService + func (s *ClusterHealthService) Local(local bool) *ClusterHealthService + func (s *ClusterHealthService) MasterTimeout(masterTimeout string) *ClusterHealthService + func (s *ClusterHealthService) Pretty(pretty bool) *ClusterHealthService + func (s *ClusterHealthService) Timeout(timeout string) *ClusterHealthService + func (s *ClusterHealthService) Validate() error + func (s *ClusterHealthService) WaitForActiveShards(waitForActiveShards int) *ClusterHealthService + func (s *ClusterHealthService) WaitForGreenStatus() *ClusterHealthService + func (s *ClusterHealthService) WaitForNoRelocatingShards(waitForNoRelocatingShards bool) *ClusterHealthService + func (s *ClusterHealthService) WaitForNodes(waitForNodes string) *ClusterHealthService + func (s *ClusterHealthService) WaitForStatus(waitForStatus string) *ClusterHealthService + func (s *ClusterHealthService) WaitForYellowStatus() *ClusterHealthService + type ClusterIndexHealth struct + ActivePrimaryShards int + ActiveShards int + InitializingShards int + NumberOfReplicas int + NumberOfShards int + RelocatingShards int + Shards map[string]*ClusterShardHealth + Status string + UnassignedShards int + ValidationFailures []string + type ClusterShardHealth struct + ActiveShards int + InitializingShards int + PrimaryActive bool + RelocatingShards int + Status string + UnassignedShards int + type ClusterStateResponse struct + Blocks map[string]*clusterBlocks + ClusterName string + Customs map[string]interface{} + MasterNode string + Metadata *clusterStateMetadata + Nodes map[string]*discoveryNode + RoutingNodes *clusterStateRoutingNode + RoutingTable map[string]*clusterStateRoutingTable + StateUUID string + Version int64 + type ClusterStateService struct + func NewClusterStateService(client *Client) *ClusterStateService + func (s *ClusterStateService) AllowNoIndices(allowNoIndices bool) *ClusterStateService + func (s *ClusterStateService) Do(ctx context.Context) (*ClusterStateResponse, error) + func (s *ClusterStateService) ExpandWildcards(expandWildcards string) *ClusterStateService + func (s *ClusterStateService) FlatSettings(flatSettings bool) *ClusterStateService + func (s *ClusterStateService) IgnoreUnavailable(ignoreUnavailable bool) *ClusterStateService + func (s *ClusterStateService) Index(indices ...string) *ClusterStateService + func (s *ClusterStateService) Local(local bool) *ClusterStateService + func (s *ClusterStateService) MasterTimeout(masterTimeout string) *ClusterStateService + func (s *ClusterStateService) Metric(metrics ...string) *ClusterStateService + func (s *ClusterStateService) Pretty(pretty bool) *ClusterStateService + func (s *ClusterStateService) Validate() error + type ClusterStatsIndices struct + Completion *ClusterStatsIndicesCompletion + Count int + Docs *ClusterStatsIndicesDocs + FieldData *ClusterStatsIndicesFieldData + FilterCache *ClusterStatsIndicesFilterCache + IdCache *ClusterStatsIndicesIdCache + Percolate *ClusterStatsIndicesPercolate + Segments *ClusterStatsIndicesSegments + Shards *ClusterStatsIndicesShards + Store *ClusterStatsIndicesStore + type ClusterStatsIndicesCompletion struct + Fields map[string]struct{ ... } + Size string + SizeInBytes int64 + type ClusterStatsIndicesDocs struct + Count int + Deleted int + type ClusterStatsIndicesFieldData struct + Evictions int64 + Fields map[string]struct{ ... } + MemorySize string + MemorySizeInBytes int64 + type ClusterStatsIndicesFilterCache struct + Evictions int64 + MemorySize string + MemorySizeInBytes int64 + type ClusterStatsIndicesIdCache struct + MemorySize string + MemorySizeInBytes int64 + type ClusterStatsIndicesPercolate struct + Current int64 + MemorySize string + MemorySizeInBytes int64 + Queries int64 + Time string + TimeInBytes int64 + Total int64 + type ClusterStatsIndicesSegments struct + Count int64 + FixedBitSet string + FixedBitSetInBytes int64 + IndexWriterMaxMemory string + IndexWriterMaxMemoryInBytes int64 + IndexWriterMemory string + IndexWriterMemoryInBytes int64 + Memory string + MemoryInBytes int64 + VersionMapMemory string + VersionMapMemoryInBytes int64 + type ClusterStatsIndicesShards struct + Index *ClusterStatsIndicesShardsIndex + Primaries int + Replication float64 + Total int + type ClusterStatsIndicesShardsIndex struct + Primaries *ClusterStatsIndicesShardsIndexIntMinMax + Replication *ClusterStatsIndicesShardsIndexFloat64MinMax + Shards *ClusterStatsIndicesShardsIndexIntMinMax + type ClusterStatsIndicesShardsIndexFloat64MinMax struct + Avg float64 + Max float64 + Min float64 + type ClusterStatsIndicesShardsIndexIntMinMax struct + Avg float64 + Max int + Min int + type ClusterStatsIndicesStore struct + Size string + SizeInBytes int64 + type ClusterStatsNodes struct + Count *ClusterStatsNodesCount + FS *ClusterStatsNodesFsStats + JVM *ClusterStatsNodesJvmStats + OS *ClusterStatsNodesOsStats + Plugins []*ClusterStatsNodesPlugin + Process *ClusterStatsNodesProcessStats + Versions []string + type ClusterStatsNodesCount struct + CoordinatingOnly int + Data int + Ingest int + Master int + Total int + type ClusterStatsNodesFsStats struct + Available string + AvailableInBytes int64 + Dev string + DiskIOOp int64 + DiskIOSize string + DiskIOSizeInBytes int64 + DiskQueue string + DiskReadSize string + DiskReadSizeInBytes int64 + DiskReads int64 + DiskServiceTime string + DiskWriteSize string + DiskWriteSizeInBytes int64 + DiskWrites int64 + Free string + FreeInBytes int64 + Mount string + Path string + Total string + TotalInBytes int64 + type ClusterStatsNodesJvmStats struct + MaxUptime string + MaxUptimeInMillis int64 + Mem *ClusterStatsNodesJvmStatsMem + Threads int64 + Versions []*ClusterStatsNodesJvmStatsVersion + type ClusterStatsNodesJvmStatsMem struct + HeapMax string + HeapMaxInBytes int64 + HeapUsed string + HeapUsedInBytes int64 + type ClusterStatsNodesJvmStatsVersion struct + Count int + VMName string + VMVendor string + VMVersion string + Version string + type ClusterStatsNodesOsStats struct + AvailableProcessors int + CPU []*ClusterStatsNodesOsStatsCPU + Mem *ClusterStatsNodesOsStatsMem + type ClusterStatsNodesOsStatsCPU struct + CacheSize string + CacheSizeInBytes int64 + CoresPerSocket int + Count int + MHz int + Model string + TotalCores int + TotalSockets int + Vendor string + type ClusterStatsNodesOsStatsMem struct + Total string + TotalInBytes int64 + type ClusterStatsNodesPlugin struct + Description string + JVM bool + Name string + Site bool + URL string + Version string + type ClusterStatsNodesProcessStats struct + CPU *ClusterStatsNodesProcessStatsCPU + OpenFileDescriptors *ClusterStatsNodesProcessStatsOpenFileDescriptors + type ClusterStatsNodesProcessStatsCPU struct + Percent float64 + type ClusterStatsNodesProcessStatsOpenFileDescriptors struct + Avg int64 + Max int64 + Min int64 + type ClusterStatsResponse struct + ClusterName string + ClusterUUID string + Indices *ClusterStatsIndices + Nodes *ClusterStatsNodes + Status string + Timestamp int64 + type ClusterStatsService struct + func NewClusterStatsService(client *Client) *ClusterStatsService + func (s *ClusterStatsService) Do(ctx context.Context) (*ClusterStatsResponse, error) + func (s *ClusterStatsService) FlatSettings(flatSettings bool) *ClusterStatsService + func (s *ClusterStatsService) Human(human bool) *ClusterStatsService + func (s *ClusterStatsService) NodeId(nodeId []string) *ClusterStatsService + func (s *ClusterStatsService) Pretty(pretty bool) *ClusterStatsService + func (s *ClusterStatsService) Validate() error + type CollapseBuilder struct + func NewCollapseBuilder(field string) *CollapseBuilder + func (b *CollapseBuilder) Field(field string) *CollapseBuilder + func (b *CollapseBuilder) InnerHit(innerHit *InnerHit) *CollapseBuilder + func (b *CollapseBuilder) MaxConcurrentGroupRequests(max int) *CollapseBuilder + func (b *CollapseBuilder) Source() (interface{}, error) + type CollectorResult struct + Children []CollectorResult + Name string + Reason string + Time string + TimeNanos int64 + type CommonTermsQuery struct + func NewCommonTermsQuery(name string, text interface{}) *CommonTermsQuery + func (q *CommonTermsQuery) Analyzer(analyzer string) *CommonTermsQuery + func (q *CommonTermsQuery) Boost(boost float64) *CommonTermsQuery + func (q *CommonTermsQuery) CutoffFrequency(f float64) *CommonTermsQuery + func (q *CommonTermsQuery) HighFreq(f float64) *CommonTermsQuery + func (q *CommonTermsQuery) HighFreqMinimumShouldMatch(minShouldMatch string) *CommonTermsQuery + func (q *CommonTermsQuery) HighFreqOperator(op string) *CommonTermsQuery + func (q *CommonTermsQuery) LowFreq(f float64) *CommonTermsQuery + func (q *CommonTermsQuery) LowFreqMinimumShouldMatch(minShouldMatch string) *CommonTermsQuery + func (q *CommonTermsQuery) LowFreqOperator(op string) *CommonTermsQuery + func (q *CommonTermsQuery) QueryName(queryName string) *CommonTermsQuery + func (q *CommonTermsQuery) Source() (interface{}, error) + type CompletionSuggester struct + func NewCompletionSuggester(name string) *CompletionSuggester + func (q *CompletionSuggester) Analyzer(analyzer string) *CompletionSuggester + func (q *CompletionSuggester) ContextQueries(queries ...SuggesterContextQuery) *CompletionSuggester + func (q *CompletionSuggester) ContextQuery(query SuggesterContextQuery) *CompletionSuggester + func (q *CompletionSuggester) Field(field string) *CompletionSuggester + func (q *CompletionSuggester) Fuzziness(fuzziness interface{}) *CompletionSuggester + func (q *CompletionSuggester) FuzzyOptions(options *FuzzyCompletionSuggesterOptions) *CompletionSuggester + func (q *CompletionSuggester) Name() string + func (q *CompletionSuggester) Prefix(prefix string) *CompletionSuggester + func (q *CompletionSuggester) PrefixWithEditDistance(prefix string, editDistance interface{}) *CompletionSuggester + func (q *CompletionSuggester) PrefixWithOptions(prefix string, options *FuzzyCompletionSuggesterOptions) *CompletionSuggester + func (q *CompletionSuggester) Regex(regex string) *CompletionSuggester + func (q *CompletionSuggester) RegexOptions(options *RegexCompletionSuggesterOptions) *CompletionSuggester + func (q *CompletionSuggester) RegexWithOptions(regex string, options *RegexCompletionSuggesterOptions) *CompletionSuggester + func (q *CompletionSuggester) ShardSize(shardSize int) *CompletionSuggester + func (q *CompletionSuggester) Size(size int) *CompletionSuggester + func (q *CompletionSuggester) SkipDuplicates(skipDuplicates bool) *CompletionSuggester + func (q *CompletionSuggester) Source(includeName bool) (interface{}, error) + func (q *CompletionSuggester) Text(text string) *CompletionSuggester + type CompositeAggregation struct + func NewCompositeAggregation() *CompositeAggregation + func (a *CompositeAggregation) AggregateAfter(after map[string]interface{}) *CompositeAggregation + func (a *CompositeAggregation) Meta(metaData map[string]interface{}) *CompositeAggregation + func (a *CompositeAggregation) Size(size int) *CompositeAggregation + func (a *CompositeAggregation) Source() (interface{}, error) + func (a *CompositeAggregation) Sources(sources ...CompositeAggregationValuesSource) *CompositeAggregation + func (a *CompositeAggregation) SubAggregation(name string, subAggregation Aggregation) *CompositeAggregation + type CompositeAggregationDateHistogramValuesSource struct + func NewCompositeAggregationDateHistogramValuesSource(name string, interval interface{}) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Asc() *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Desc() *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Field(field string) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Interval(interval interface{}) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Missing(missing interface{}) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Order(order string) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Script(script *Script) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) Source() (interface{}, error) + func (a *CompositeAggregationDateHistogramValuesSource) TimeZone(timeZone string) *CompositeAggregationDateHistogramValuesSource + func (a *CompositeAggregationDateHistogramValuesSource) ValueType(valueType string) *CompositeAggregationDateHistogramValuesSource + type CompositeAggregationHistogramValuesSource struct + func NewCompositeAggregationHistogramValuesSource(name string, interval float64) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Asc() *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Desc() *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Field(field string) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Interval(interval float64) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Missing(missing interface{}) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Order(order string) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Script(script *Script) *CompositeAggregationHistogramValuesSource + func (a *CompositeAggregationHistogramValuesSource) Source() (interface{}, error) + func (a *CompositeAggregationHistogramValuesSource) ValueType(valueType string) *CompositeAggregationHistogramValuesSource + type CompositeAggregationTermsValuesSource struct + func NewCompositeAggregationTermsValuesSource(name string) *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Asc() *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Desc() *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Field(field string) *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Missing(missing interface{}) *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Order(order string) *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Script(script *Script) *CompositeAggregationTermsValuesSource + func (a *CompositeAggregationTermsValuesSource) Source() (interface{}, error) + func (a *CompositeAggregationTermsValuesSource) ValueType(valueType string) *CompositeAggregationTermsValuesSource + type CompositeAggregationValuesSource interface + Source func() (interface{}, error) + type ConstantBackoff struct + func NewConstantBackoff(interval time.Duration) *ConstantBackoff + func (b *ConstantBackoff) Next(retry int) (time.Duration, bool) + type ConstantScoreQuery struct + func NewConstantScoreQuery(filter Query) *ConstantScoreQuery + func (q *ConstantScoreQuery) Boost(boost float64) *ConstantScoreQuery + func (q *ConstantScoreQuery) Source() (interface{}, error) + type ContextSuggester struct + func NewContextSuggester(name string) *ContextSuggester + func (q *ContextSuggester) ContextQueries(queries ...SuggesterContextQuery) *ContextSuggester + func (q *ContextSuggester) ContextQuery(query SuggesterContextQuery) *ContextSuggester + func (q *ContextSuggester) Field(field string) *ContextSuggester + func (q *ContextSuggester) Name() string + func (q *ContextSuggester) Prefix(prefix string) *ContextSuggester + func (q *ContextSuggester) Size(size int) *ContextSuggester + func (q *ContextSuggester) Source(includeName bool) (interface{}, error) + type CountResponse struct + Count int64 + Shards shardsInfo + type CountService struct + func NewCountService(client *Client) *CountService + func (s *CountService) AllowNoIndices(allowNoIndices bool) *CountService + func (s *CountService) AnalyzeWildcard(analyzeWildcard bool) *CountService + func (s *CountService) Analyzer(analyzer string) *CountService + func (s *CountService) BodyJson(body interface{}) *CountService + func (s *CountService) BodyString(body string) *CountService + func (s *CountService) DefaultOperator(defaultOperator string) *CountService + func (s *CountService) Df(df string) *CountService + func (s *CountService) Do(ctx context.Context) (int64, error) + func (s *CountService) ExpandWildcards(expandWildcards string) *CountService + func (s *CountService) IgnoreUnavailable(ignoreUnavailable bool) *CountService + func (s *CountService) Index(index ...string) *CountService + func (s *CountService) Lenient(lenient bool) *CountService + func (s *CountService) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *CountService + func (s *CountService) MinScore(minScore interface{}) *CountService + func (s *CountService) Preference(preference string) *CountService + func (s *CountService) Pretty(pretty bool) *CountService + func (s *CountService) Q(q string) *CountService + func (s *CountService) Query(query Query) *CountService + func (s *CountService) Routing(routing string) *CountService + func (s *CountService) TerminateAfter(terminateAfter int) *CountService + func (s *CountService) Type(typ ...string) *CountService + func (s *CountService) Validate() error + type CumulativeSumAggregation struct + func NewCumulativeSumAggregation() *CumulativeSumAggregation + func (a *CumulativeSumAggregation) BucketsPath(bucketsPaths ...string) *CumulativeSumAggregation + func (a *CumulativeSumAggregation) Format(format string) *CumulativeSumAggregation + func (a *CumulativeSumAggregation) Meta(metaData map[string]interface{}) *CumulativeSumAggregation + func (a *CumulativeSumAggregation) Source() (interface{}, error) + type DateHistogramAggregation struct + func NewDateHistogramAggregation() *DateHistogramAggregation + func (a *DateHistogramAggregation) ExtendedBounds(min, max interface{}) *DateHistogramAggregation + func (a *DateHistogramAggregation) ExtendedBoundsMax(max interface{}) *DateHistogramAggregation + func (a *DateHistogramAggregation) ExtendedBoundsMin(min interface{}) *DateHistogramAggregation + func (a *DateHistogramAggregation) Field(field string) *DateHistogramAggregation + func (a *DateHistogramAggregation) Format(format string) *DateHistogramAggregation + func (a *DateHistogramAggregation) Interval(interval string) *DateHistogramAggregation + func (a *DateHistogramAggregation) Meta(metaData map[string]interface{}) *DateHistogramAggregation + func (a *DateHistogramAggregation) MinDocCount(minDocCount int64) *DateHistogramAggregation + func (a *DateHistogramAggregation) Missing(missing interface{}) *DateHistogramAggregation + func (a *DateHistogramAggregation) Offset(offset string) *DateHistogramAggregation + func (a *DateHistogramAggregation) Order(order string, asc bool) *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByAggregation(aggName string, asc bool) *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByAggregationAndMetric(aggName, metric string, asc bool) *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByCount(asc bool) *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByCountAsc() *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByCountDesc() *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByKey(asc bool) *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByKeyAsc() *DateHistogramAggregation + func (a *DateHistogramAggregation) OrderByKeyDesc() *DateHistogramAggregation + func (a *DateHistogramAggregation) Script(script *Script) *DateHistogramAggregation + func (a *DateHistogramAggregation) Source() (interface{}, error) + func (a *DateHistogramAggregation) SubAggregation(name string, subAggregation Aggregation) *DateHistogramAggregation + func (a *DateHistogramAggregation) TimeZone(timeZone string) *DateHistogramAggregation + type DateRangeAggregation struct + func NewDateRangeAggregation() *DateRangeAggregation + func (a *DateRangeAggregation) AddRange(from, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) AddRangeWithKey(key string, from, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) AddUnboundedFrom(to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) AddUnboundedFromWithKey(key string, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) AddUnboundedTo(from interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) AddUnboundedToWithKey(key string, from interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) Between(from, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) BetweenWithKey(key string, from, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) Field(field string) *DateRangeAggregation + func (a *DateRangeAggregation) Format(format string) *DateRangeAggregation + func (a *DateRangeAggregation) Gt(from interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) GtWithKey(key string, from interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) Keyed(keyed bool) *DateRangeAggregation + func (a *DateRangeAggregation) Lt(to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) LtWithKey(key string, to interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) Meta(metaData map[string]interface{}) *DateRangeAggregation + func (a *DateRangeAggregation) Script(script *Script) *DateRangeAggregation + func (a *DateRangeAggregation) Source() (interface{}, error) + func (a *DateRangeAggregation) SubAggregation(name string, subAggregation Aggregation) *DateRangeAggregation + func (a *DateRangeAggregation) TimeZone(timeZone string) *DateRangeAggregation + func (a *DateRangeAggregation) Unmapped(unmapped bool) *DateRangeAggregation + type DateRangeAggregationEntry struct + From interface{} + Key string + To interface{} + type Decoder interface + Decode func(data []byte, v interface{}) error + type DefaultDecoder struct + func (u *DefaultDecoder) Decode(data []byte, v interface{}) error + type DeleteByQueryService struct + func NewDeleteByQueryService(client *Client) *DeleteByQueryService + func (s *DeleteByQueryService) AbortOnVersionConflict() *DeleteByQueryService + func (s *DeleteByQueryService) AllowNoIndices(allow bool) *DeleteByQueryService + func (s *DeleteByQueryService) AnalyzeWildcard(analyzeWildcard bool) *DeleteByQueryService + func (s *DeleteByQueryService) Analyzer(analyzer string) *DeleteByQueryService + func (s *DeleteByQueryService) Body(body string) *DeleteByQueryService + func (s *DeleteByQueryService) Conflicts(conflicts string) *DeleteByQueryService + func (s *DeleteByQueryService) DF(defaultField string) *DeleteByQueryService + func (s *DeleteByQueryService) DefaultField(defaultField string) *DeleteByQueryService + func (s *DeleteByQueryService) DefaultOperator(defaultOperator string) *DeleteByQueryService + func (s *DeleteByQueryService) Do(ctx context.Context) (*BulkIndexByScrollResponse, error) + func (s *DeleteByQueryService) DoAsync(ctx context.Context) (*StartTaskResult, error) + func (s *DeleteByQueryService) DocvalueFields(docvalueFields ...string) *DeleteByQueryService + func (s *DeleteByQueryService) ExpandWildcards(expand string) *DeleteByQueryService + func (s *DeleteByQueryService) Explain(explain bool) *DeleteByQueryService + func (s *DeleteByQueryService) From(from int) *DeleteByQueryService + func (s *DeleteByQueryService) IgnoreUnavailable(ignore bool) *DeleteByQueryService + func (s *DeleteByQueryService) Index(index ...string) *DeleteByQueryService + func (s *DeleteByQueryService) Lenient(lenient bool) *DeleteByQueryService + func (s *DeleteByQueryService) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *DeleteByQueryService + func (s *DeleteByQueryService) Preference(preference string) *DeleteByQueryService + func (s *DeleteByQueryService) Pretty(pretty bool) *DeleteByQueryService + func (s *DeleteByQueryService) ProceedOnVersionConflict() *DeleteByQueryService + func (s *DeleteByQueryService) Q(query string) *DeleteByQueryService + func (s *DeleteByQueryService) Query(query Query) *DeleteByQueryService + func (s *DeleteByQueryService) QueryString(query string) *DeleteByQueryService + func (s *DeleteByQueryService) Refresh(refresh string) *DeleteByQueryService + func (s *DeleteByQueryService) RequestCache(requestCache bool) *DeleteByQueryService + func (s *DeleteByQueryService) RequestsPerSecond(requestsPerSecond int) *DeleteByQueryService + func (s *DeleteByQueryService) Routing(routing ...string) *DeleteByQueryService + func (s *DeleteByQueryService) Scroll(scroll string) *DeleteByQueryService + func (s *DeleteByQueryService) ScrollSize(scrollSize int) *DeleteByQueryService + func (s *DeleteByQueryService) SearchTimeout(searchTimeout string) *DeleteByQueryService + func (s *DeleteByQueryService) SearchType(searchType string) *DeleteByQueryService + func (s *DeleteByQueryService) Size(size int) *DeleteByQueryService + func (s *DeleteByQueryService) Sort(sort ...string) *DeleteByQueryService + func (s *DeleteByQueryService) SortByField(field string, ascending bool) *DeleteByQueryService + func (s *DeleteByQueryService) Stats(stats ...string) *DeleteByQueryService + func (s *DeleteByQueryService) StoredFields(storedFields ...string) *DeleteByQueryService + func (s *DeleteByQueryService) SuggestField(suggestField string) *DeleteByQueryService + func (s *DeleteByQueryService) SuggestMode(suggestMode string) *DeleteByQueryService + func (s *DeleteByQueryService) SuggestSize(suggestSize int) *DeleteByQueryService + func (s *DeleteByQueryService) SuggestText(suggestText string) *DeleteByQueryService + func (s *DeleteByQueryService) TerminateAfter(terminateAfter int) *DeleteByQueryService + func (s *DeleteByQueryService) Timeout(timeout string) *DeleteByQueryService + func (s *DeleteByQueryService) TimeoutInMillis(timeoutInMillis int) *DeleteByQueryService + func (s *DeleteByQueryService) TrackScores(trackScores bool) *DeleteByQueryService + func (s *DeleteByQueryService) Type(typ ...string) *DeleteByQueryService + func (s *DeleteByQueryService) Validate() error + func (s *DeleteByQueryService) Version(version bool) *DeleteByQueryService + func (s *DeleteByQueryService) WaitForActiveShards(waitForActiveShards string) *DeleteByQueryService + func (s *DeleteByQueryService) WaitForCompletion(waitForCompletion bool) *DeleteByQueryService + func (s *DeleteByQueryService) XSource(xSource ...string) *DeleteByQueryService + func (s *DeleteByQueryService) XSourceExclude(xSourceExclude ...string) *DeleteByQueryService + func (s *DeleteByQueryService) XSourceInclude(xSourceInclude ...string) *DeleteByQueryService + type DeleteResponse struct + ForcedRefresh bool + Id string + Index string + PrimaryTerm int64 + Result string + SeqNo int64 + Shards *shardsInfo + Status int + Type string + Version int64 + type DeleteService struct + func NewDeleteService(client *Client) *DeleteService + func (s *DeleteService) Do(ctx context.Context) (*DeleteResponse, error) + func (s *DeleteService) Id(id string) *DeleteService + func (s *DeleteService) Index(index string) *DeleteService + func (s *DeleteService) Parent(parent string) *DeleteService + func (s *DeleteService) Pretty(pretty bool) *DeleteService + func (s *DeleteService) Refresh(refresh string) *DeleteService + func (s *DeleteService) Routing(routing string) *DeleteService + func (s *DeleteService) Timeout(timeout string) *DeleteService + func (s *DeleteService) Type(typ string) *DeleteService + func (s *DeleteService) Validate() error + func (s *DeleteService) Version(version interface{}) *DeleteService + func (s *DeleteService) VersionType(versionType string) *DeleteService + func (s *DeleteService) WaitForActiveShards(waitForActiveShards string) *DeleteService + type DerivativeAggregation struct + func NewDerivativeAggregation() *DerivativeAggregation + func (a *DerivativeAggregation) BucketsPath(bucketsPaths ...string) *DerivativeAggregation + func (a *DerivativeAggregation) Format(format string) *DerivativeAggregation + func (a *DerivativeAggregation) GapInsertZeros() *DerivativeAggregation + func (a *DerivativeAggregation) GapPolicy(gapPolicy string) *DerivativeAggregation + func (a *DerivativeAggregation) GapSkip() *DerivativeAggregation + func (a *DerivativeAggregation) Meta(metaData map[string]interface{}) *DerivativeAggregation + func (a *DerivativeAggregation) Source() (interface{}, error) + func (a *DerivativeAggregation) Unit(unit string) *DerivativeAggregation + type DirectCandidateGenerator struct + func NewDirectCandidateGenerator(field string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Accuracy(accuracy float64) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Field(field string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) MaxEdits(maxEdits int) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) MaxInspections(maxInspections int) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) MaxTermFreq(maxTermFreq float64) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) MinDocFreq(minDocFreq float64) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) MinWordLength(minWordLength int) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) PostFilter(postFilter string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) PreFilter(preFilter string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) PrefixLength(prefixLength int) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Size(size int) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Sort(sort string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Source() (interface{}, error) + func (g *DirectCandidateGenerator) StringDistance(stringDistance string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) SuggestMode(suggestMode string) *DirectCandidateGenerator + func (g *DirectCandidateGenerator) Type() string + type DisMaxQuery struct + func NewDisMaxQuery() *DisMaxQuery + func (q *DisMaxQuery) Boost(boost float64) *DisMaxQuery + func (q *DisMaxQuery) Query(queries ...Query) *DisMaxQuery + func (q *DisMaxQuery) QueryName(queryName string) *DisMaxQuery + func (q *DisMaxQuery) Source() (interface{}, error) + func (q *DisMaxQuery) TieBreaker(tieBreaker float64) *DisMaxQuery + type DiscoveryNode struct + Attributes map[string]interface{} + Host string + IP string + Name string + Roles []string + Tasks map[string]*TaskInfo + TransportAddress string + type DiversifiedSamplerAggregation struct + func NewDiversifiedSamplerAggregation() *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) ExecutionHint(hint string) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) Field(field string) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) MaxDocsPerValue(maxDocsPerValue int) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) Meta(metaData map[string]interface{}) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) Script(script *Script) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) ShardSize(shardSize int) *DiversifiedSamplerAggregation + func (a *DiversifiedSamplerAggregation) Source() (interface{}, error) + func (a *DiversifiedSamplerAggregation) SubAggregation(name string, subAggregation Aggregation) *DiversifiedSamplerAggregation + type EWMAMovAvgModel struct + func NewEWMAMovAvgModel() *EWMAMovAvgModel + func (m *EWMAMovAvgModel) Alpha(alpha float64) *EWMAMovAvgModel + func (m *EWMAMovAvgModel) Name() string + func (m *EWMAMovAvgModel) Settings() map[string]interface{} + type Error struct + Details *ErrorDetails + Status int + func (e *Error) Error() string + type ErrorDetails struct + CausedBy map[string]interface{} + FailedShards []map[string]interface{} + Grouped bool + Index string + Phase string + Reason string + ResourceId string + ResourceType string + RootCause []*ErrorDetails + Type string + type ExistsQuery struct + func NewExistsQuery(name string) *ExistsQuery + func (q *ExistsQuery) QueryName(queryName string) *ExistsQuery + func (q *ExistsQuery) Source() (interface{}, error) + type ExistsService struct + func NewExistsService(client *Client) *ExistsService + func (s *ExistsService) Do(ctx context.Context) (bool, error) + func (s *ExistsService) Id(id string) *ExistsService + func (s *ExistsService) Index(index string) *ExistsService + func (s *ExistsService) Parent(parent string) *ExistsService + func (s *ExistsService) Preference(preference string) *ExistsService + func (s *ExistsService) Pretty(pretty bool) *ExistsService + func (s *ExistsService) Realtime(realtime bool) *ExistsService + func (s *ExistsService) Refresh(refresh string) *ExistsService + func (s *ExistsService) Routing(routing string) *ExistsService + func (s *ExistsService) Type(typ string) *ExistsService + func (s *ExistsService) Validate() error + type ExplainResponse struct + Explanation map[string]interface{} + Id string + Index string + Matched bool + Type string + type ExplainService struct + func NewExplainService(client *Client) *ExplainService + func (s *ExplainService) AnalyzeWildcard(analyzeWildcard bool) *ExplainService + func (s *ExplainService) Analyzer(analyzer string) *ExplainService + func (s *ExplainService) BodyJson(body interface{}) *ExplainService + func (s *ExplainService) BodyString(body string) *ExplainService + func (s *ExplainService) DefaultOperator(defaultOperator string) *ExplainService + func (s *ExplainService) Df(df string) *ExplainService + func (s *ExplainService) Do(ctx context.Context) (*ExplainResponse, error) + func (s *ExplainService) Fields(fields ...string) *ExplainService + func (s *ExplainService) Id(id string) *ExplainService + func (s *ExplainService) Index(index string) *ExplainService + func (s *ExplainService) Lenient(lenient bool) *ExplainService + func (s *ExplainService) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *ExplainService + func (s *ExplainService) Parent(parent string) *ExplainService + func (s *ExplainService) Preference(preference string) *ExplainService + func (s *ExplainService) Pretty(pretty bool) *ExplainService + func (s *ExplainService) Q(q string) *ExplainService + func (s *ExplainService) Query(query Query) *ExplainService + func (s *ExplainService) Routing(routing string) *ExplainService + func (s *ExplainService) Source(source string) *ExplainService + func (s *ExplainService) Type(typ string) *ExplainService + func (s *ExplainService) Validate() error + func (s *ExplainService) XSource(xSource ...string) *ExplainService + func (s *ExplainService) XSourceExclude(xSourceExclude ...string) *ExplainService + func (s *ExplainService) XSourceInclude(xSourceInclude ...string) *ExplainService + type ExponentialBackoff struct + func NewExponentialBackoff(initialTimeout, maxTimeout time.Duration) *ExponentialBackoff + func (b *ExponentialBackoff) Next(retry int) (time.Duration, bool) + type ExponentialDecayFunction struct + func NewExponentialDecayFunction() *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) Decay(decay float64) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) FieldName(fieldName string) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) GetWeight() *float64 + func (fn *ExponentialDecayFunction) MultiValueMode(mode string) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) Name() string + func (fn *ExponentialDecayFunction) Offset(offset interface{}) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) Origin(origin interface{}) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) Scale(scale interface{}) *ExponentialDecayFunction + func (fn *ExponentialDecayFunction) Source() (interface{}, error) + func (fn *ExponentialDecayFunction) Weight(weight float64) *ExponentialDecayFunction + type ExtendedStatsAggregation struct + func NewExtendedStatsAggregation() *ExtendedStatsAggregation + func (a *ExtendedStatsAggregation) Field(field string) *ExtendedStatsAggregation + func (a *ExtendedStatsAggregation) Format(format string) *ExtendedStatsAggregation + func (a *ExtendedStatsAggregation) Meta(metaData map[string]interface{}) *ExtendedStatsAggregation + func (a *ExtendedStatsAggregation) Script(script *Script) *ExtendedStatsAggregation + func (a *ExtendedStatsAggregation) Source() (interface{}, error) + func (a *ExtendedStatsAggregation) SubAggregation(name string, subAggregation Aggregation) *ExtendedStatsAggregation + type FailedNodeException struct + NodeId string + type FetchSourceContext struct + func NewFetchSourceContext(fetchSource bool) *FetchSourceContext + func (fsc *FetchSourceContext) Exclude(excludes ...string) *FetchSourceContext + func (fsc *FetchSourceContext) FetchSource() bool + func (fsc *FetchSourceContext) Include(includes ...string) *FetchSourceContext + func (fsc *FetchSourceContext) Query() url.Values + func (fsc *FetchSourceContext) SetFetchSource(fetchSource bool) + func (fsc *FetchSourceContext) Source() (interface{}, error) + type FieldCaps struct + Aggregatable bool + Indices []string + NonAggregatableIndices []string + NonSearchableIndices []string + Searchable bool + Type string + type FieldCapsRequest struct + Fields []string + type FieldCapsResponse struct + Fields map[string]FieldCaps + type FieldCapsService struct + func NewFieldCapsService(client *Client) *FieldCapsService + func (s *FieldCapsService) AllowNoIndices(allowNoIndices bool) *FieldCapsService + func (s *FieldCapsService) BodyJson(body interface{}) *FieldCapsService + func (s *FieldCapsService) BodyString(body string) *FieldCapsService + func (s *FieldCapsService) Do(ctx context.Context) (*FieldCapsResponse, error) + func (s *FieldCapsService) ExpandWildcards(expandWildcards string) *FieldCapsService + func (s *FieldCapsService) Fields(fields ...string) *FieldCapsService + func (s *FieldCapsService) IgnoreUnavailable(ignoreUnavailable bool) *FieldCapsService + func (s *FieldCapsService) Index(index ...string) *FieldCapsService + func (s *FieldCapsService) Pretty(pretty bool) *FieldCapsService + func (s *FieldCapsService) Validate() error + type FieldSort struct + func NewFieldSort(fieldName string) *FieldSort + func (s *FieldSort) Asc() *FieldSort + func (s *FieldSort) Desc() *FieldSort + func (s *FieldSort) FieldName(fieldName string) *FieldSort + func (s *FieldSort) Missing(missing interface{}) *FieldSort + func (s *FieldSort) NestedFilter(nestedFilter Query) *FieldSort + func (s *FieldSort) NestedPath(nestedPath string) *FieldSort + func (s *FieldSort) NestedSort(nestedSort *NestedSort) *FieldSort + func (s *FieldSort) Order(ascending bool) *FieldSort + func (s *FieldSort) SortMode(sortMode string) *FieldSort + func (s *FieldSort) Source() (interface{}, error) + func (s *FieldSort) UnmappedType(typ string) *FieldSort + type FieldStatistics struct + DocCount int64 + SumDocFreq int64 + SumTtf int64 + type FieldValueFactorFunction struct + func NewFieldValueFactorFunction() *FieldValueFactorFunction + func (fn *FieldValueFactorFunction) Factor(factor float64) *FieldValueFactorFunction + func (fn *FieldValueFactorFunction) Field(field string) *FieldValueFactorFunction + func (fn *FieldValueFactorFunction) GetWeight() *float64 + func (fn *FieldValueFactorFunction) Missing(missing float64) *FieldValueFactorFunction + func (fn *FieldValueFactorFunction) Modifier(modifier string) *FieldValueFactorFunction + func (fn *FieldValueFactorFunction) Name() string + func (fn *FieldValueFactorFunction) Source() (interface{}, error) + func (fn *FieldValueFactorFunction) Weight(weight float64) *FieldValueFactorFunction + type FilterAggregation struct + func NewFilterAggregation() *FilterAggregation + func (a *FilterAggregation) Filter(filter Query) *FilterAggregation + func (a *FilterAggregation) Meta(metaData map[string]interface{}) *FilterAggregation + func (a *FilterAggregation) Source() (interface{}, error) + func (a *FilterAggregation) SubAggregation(name string, subAggregation Aggregation) *FilterAggregation + type FiltersAggregation struct + func NewFiltersAggregation() *FiltersAggregation + func (a *FiltersAggregation) Filter(filter Query) *FiltersAggregation + func (a *FiltersAggregation) FilterWithName(name string, filter Query) *FiltersAggregation + func (a *FiltersAggregation) Filters(filters ...Query) *FiltersAggregation + func (a *FiltersAggregation) Meta(metaData map[string]interface{}) *FiltersAggregation + func (a *FiltersAggregation) Source() (interface{}, error) + func (a *FiltersAggregation) SubAggregation(name string, subAggregation Aggregation) *FiltersAggregation + type FunctionScoreQuery struct + func NewFunctionScoreQuery() *FunctionScoreQuery + func (q *FunctionScoreQuery) Add(filter Query, scoreFunc ScoreFunction) *FunctionScoreQuery + func (q *FunctionScoreQuery) AddScoreFunc(scoreFunc ScoreFunction) *FunctionScoreQuery + func (q *FunctionScoreQuery) Boost(boost float64) *FunctionScoreQuery + func (q *FunctionScoreQuery) BoostMode(boostMode string) *FunctionScoreQuery + func (q *FunctionScoreQuery) Filter(filter Query) *FunctionScoreQuery + func (q *FunctionScoreQuery) MaxBoost(maxBoost float64) *FunctionScoreQuery + func (q *FunctionScoreQuery) MinScore(minScore float64) *FunctionScoreQuery + func (q *FunctionScoreQuery) Query(query Query) *FunctionScoreQuery + func (q *FunctionScoreQuery) ScoreMode(scoreMode string) *FunctionScoreQuery + func (q *FunctionScoreQuery) Source() (interface{}, error) + type FuzzyCompletionSuggesterOptions struct + func NewFuzzyCompletionSuggesterOptions() *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) EditDistance(editDistance interface{}) *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) MaxDeterminizedStates(max int) *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) MinLength(minLength int) *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) PrefixLength(prefixLength int) *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) Source() (interface{}, error) + func (o *FuzzyCompletionSuggesterOptions) Transpositions(transpositions bool) *FuzzyCompletionSuggesterOptions + func (o *FuzzyCompletionSuggesterOptions) UnicodeAware(unicodeAware bool) *FuzzyCompletionSuggesterOptions + type FuzzyQuery struct + func NewFuzzyQuery(name string, value interface{}) *FuzzyQuery + func (q *FuzzyQuery) Boost(boost float64) *FuzzyQuery + func (q *FuzzyQuery) Fuzziness(fuzziness interface{}) *FuzzyQuery + func (q *FuzzyQuery) MaxExpansions(maxExpansions int) *FuzzyQuery + func (q *FuzzyQuery) PrefixLength(prefixLength int) *FuzzyQuery + func (q *FuzzyQuery) QueryName(queryName string) *FuzzyQuery + func (q *FuzzyQuery) Rewrite(rewrite string) *FuzzyQuery + func (q *FuzzyQuery) Source() (interface{}, error) + func (q *FuzzyQuery) Transpositions(transpositions bool) *FuzzyQuery + type GNDSignificanceHeuristic struct + func NewGNDSignificanceHeuristic() *GNDSignificanceHeuristic + func (sh *GNDSignificanceHeuristic) BackgroundIsSuperset(backgroundIsSuperset bool) *GNDSignificanceHeuristic + func (sh *GNDSignificanceHeuristic) Name() string + func (sh *GNDSignificanceHeuristic) Source() (interface{}, error) + type GaussDecayFunction struct + func NewGaussDecayFunction() *GaussDecayFunction + func (fn *GaussDecayFunction) Decay(decay float64) *GaussDecayFunction + func (fn *GaussDecayFunction) FieldName(fieldName string) *GaussDecayFunction + func (fn *GaussDecayFunction) GetWeight() *float64 + func (fn *GaussDecayFunction) MultiValueMode(mode string) *GaussDecayFunction + func (fn *GaussDecayFunction) Name() string + func (fn *GaussDecayFunction) Offset(offset interface{}) *GaussDecayFunction + func (fn *GaussDecayFunction) Origin(origin interface{}) *GaussDecayFunction + func (fn *GaussDecayFunction) Scale(scale interface{}) *GaussDecayFunction + func (fn *GaussDecayFunction) Source() (interface{}, error) + func (fn *GaussDecayFunction) Weight(weight float64) *GaussDecayFunction + type GeoBoundingBoxQuery struct + func NewGeoBoundingBoxQuery(name string) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) BottomLeft(bottom, left float64) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) BottomLeftFromGeoPoint(point *GeoPoint) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) BottomRight(bottom, right float64) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) BottomRightFromGeoPoint(point *GeoPoint) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) QueryName(queryName string) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) Source() (interface{}, error) + func (q *GeoBoundingBoxQuery) TopLeft(top, left float64) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) TopLeftFromGeoPoint(point *GeoPoint) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) TopRight(top, right float64) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) TopRightFromGeoPoint(point *GeoPoint) *GeoBoundingBoxQuery + func (q *GeoBoundingBoxQuery) Type(typ string) *GeoBoundingBoxQuery + type GeoBoundsAggregation struct + func NewGeoBoundsAggregation() *GeoBoundsAggregation + func (a *GeoBoundsAggregation) Field(field string) *GeoBoundsAggregation + func (a *GeoBoundsAggregation) Meta(metaData map[string]interface{}) *GeoBoundsAggregation + func (a *GeoBoundsAggregation) Script(script *Script) *GeoBoundsAggregation + func (a *GeoBoundsAggregation) Source() (interface{}, error) + func (a *GeoBoundsAggregation) SubAggregation(name string, subAggregation Aggregation) *GeoBoundsAggregation + func (a *GeoBoundsAggregation) WrapLongitude(wrapLongitude bool) *GeoBoundsAggregation + type GeoCentroidAggregation struct + func NewGeoCentroidAggregation() *GeoCentroidAggregation + func (a *GeoCentroidAggregation) Field(field string) *GeoCentroidAggregation + func (a *GeoCentroidAggregation) Meta(metaData map[string]interface{}) *GeoCentroidAggregation + func (a *GeoCentroidAggregation) Script(script *Script) *GeoCentroidAggregation + func (a *GeoCentroidAggregation) Source() (interface{}, error) + func (a *GeoCentroidAggregation) SubAggregation(name string, subAggregation Aggregation) *GeoCentroidAggregation + type GeoDistanceAggregation struct + func NewGeoDistanceAggregation() *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddRange(from, to interface{}) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddRangeWithKey(key string, from, to interface{}) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddUnboundedFrom(to float64) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddUnboundedFromWithKey(key string, to float64) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddUnboundedTo(from float64) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) AddUnboundedToWithKey(key string, from float64) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Between(from, to interface{}) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) BetweenWithKey(key string, from, to interface{}) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) DistanceType(distanceType string) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Field(field string) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Meta(metaData map[string]interface{}) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Point(latLon string) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Source() (interface{}, error) + func (a *GeoDistanceAggregation) SubAggregation(name string, subAggregation Aggregation) *GeoDistanceAggregation + func (a *GeoDistanceAggregation) Unit(unit string) *GeoDistanceAggregation + type GeoDistanceQuery struct + func NewGeoDistanceQuery(name string) *GeoDistanceQuery + func (q *GeoDistanceQuery) Distance(distance string) *GeoDistanceQuery + func (q *GeoDistanceQuery) DistanceType(distanceType string) *GeoDistanceQuery + func (q *GeoDistanceQuery) GeoHash(geohash string) *GeoDistanceQuery + func (q *GeoDistanceQuery) GeoPoint(point *GeoPoint) *GeoDistanceQuery + func (q *GeoDistanceQuery) Lat(lat float64) *GeoDistanceQuery + func (q *GeoDistanceQuery) Lon(lon float64) *GeoDistanceQuery + func (q *GeoDistanceQuery) Point(lat, lon float64) *GeoDistanceQuery + func (q *GeoDistanceQuery) QueryName(queryName string) *GeoDistanceQuery + func (q *GeoDistanceQuery) Source() (interface{}, error) + type GeoDistanceSort struct + func NewGeoDistanceSort(fieldName string) *GeoDistanceSort + func (s *GeoDistanceSort) Asc() *GeoDistanceSort + func (s *GeoDistanceSort) Desc() *GeoDistanceSort + func (s *GeoDistanceSort) DistanceType(distanceType string) *GeoDistanceSort + func (s *GeoDistanceSort) FieldName(fieldName string) *GeoDistanceSort + func (s *GeoDistanceSort) GeoDistance(geoDistance string) *GeoDistanceSort + func (s *GeoDistanceSort) GeoHashes(geohashes ...string) *GeoDistanceSort + func (s *GeoDistanceSort) NestedFilter(nestedFilter Query) *GeoDistanceSort + func (s *GeoDistanceSort) NestedPath(nestedPath string) *GeoDistanceSort + func (s *GeoDistanceSort) NestedSort(nestedSort *NestedSort) *GeoDistanceSort + func (s *GeoDistanceSort) Order(ascending bool) *GeoDistanceSort + func (s *GeoDistanceSort) Point(lat, lon float64) *GeoDistanceSort + func (s *GeoDistanceSort) Points(points ...*GeoPoint) *GeoDistanceSort + func (s *GeoDistanceSort) SortMode(sortMode string) *GeoDistanceSort + func (s *GeoDistanceSort) Source() (interface{}, error) + func (s *GeoDistanceSort) Unit(unit string) *GeoDistanceSort + type GeoHashGridAggregation struct + func NewGeoHashGridAggregation() *GeoHashGridAggregation + func (a *GeoHashGridAggregation) Field(field string) *GeoHashGridAggregation + func (a *GeoHashGridAggregation) Meta(metaData map[string]interface{}) *GeoHashGridAggregation + func (a *GeoHashGridAggregation) Precision(precision interface{}) *GeoHashGridAggregation + func (a *GeoHashGridAggregation) ShardSize(shardSize int) *GeoHashGridAggregation + func (a *GeoHashGridAggregation) Size(size int) *GeoHashGridAggregation + func (a *GeoHashGridAggregation) Source() (interface{}, error) + func (a *GeoHashGridAggregation) SubAggregation(name string, subAggregation Aggregation) *GeoHashGridAggregation + type GeoPoint struct + Lat float64 + Lon float64 + func GeoPointFromLatLon(lat, lon float64) *GeoPoint + func GeoPointFromString(latLon string) (*GeoPoint, error) + func (pt *GeoPoint) Source() map[string]float64 + type GeoPolygonQuery struct + func NewGeoPolygonQuery(name string) *GeoPolygonQuery + func (q *GeoPolygonQuery) AddGeoPoint(point *GeoPoint) *GeoPolygonQuery + func (q *GeoPolygonQuery) AddPoint(lat, lon float64) *GeoPolygonQuery + func (q *GeoPolygonQuery) QueryName(queryName string) *GeoPolygonQuery + func (q *GeoPolygonQuery) Source() (interface{}, error) + type GetResult struct + Error *ErrorDetails + Fields map[string]interface{} + Found bool + Id string + Index string + Parent string + Routing string + Source *json.RawMessage + Type string + Uid string + Version *int64 + type GetService struct + func NewGetService(client *Client) *GetService + func (s *GetService) Do(ctx context.Context) (*GetResult, error) + func (s *GetService) FetchSource(fetchSource bool) *GetService + func (s *GetService) FetchSourceContext(fetchSourceContext *FetchSourceContext) *GetService + func (s *GetService) Id(id string) *GetService + func (s *GetService) IgnoreErrorsOnGeneratedFields(ignore bool) *GetService + func (s *GetService) Index(index string) *GetService + func (s *GetService) Parent(parent string) *GetService + func (s *GetService) Preference(preference string) *GetService + func (s *GetService) Pretty(pretty bool) *GetService + func (s *GetService) Realtime(realtime bool) *GetService + func (s *GetService) Refresh(refresh string) *GetService + func (s *GetService) Routing(routing string) *GetService + func (s *GetService) StoredFields(storedFields ...string) *GetService + func (s *GetService) Type(typ string) *GetService + func (s *GetService) Validate() error + func (s *GetService) Version(version interface{}) *GetService + func (s *GetService) VersionType(versionType string) *GetService + type GlobalAggregation struct + func NewGlobalAggregation() *GlobalAggregation + func (a *GlobalAggregation) Meta(metaData map[string]interface{}) *GlobalAggregation + func (a *GlobalAggregation) Source() (interface{}, error) + func (a *GlobalAggregation) SubAggregation(name string, subAggregation Aggregation) *GlobalAggregation + type HasChildQuery struct + func NewHasChildQuery(childType string, query Query) *HasChildQuery + func (q *HasChildQuery) Boost(boost float64) *HasChildQuery + func (q *HasChildQuery) InnerHit(innerHit *InnerHit) *HasChildQuery + func (q *HasChildQuery) MaxChildren(maxChildren int) *HasChildQuery + func (q *HasChildQuery) MinChildren(minChildren int) *HasChildQuery + func (q *HasChildQuery) QueryName(queryName string) *HasChildQuery + func (q *HasChildQuery) ScoreMode(scoreMode string) *HasChildQuery + func (q *HasChildQuery) ShortCircuitCutoff(shortCircuitCutoff int) *HasChildQuery + func (q *HasChildQuery) Source() (interface{}, error) + type HasParentQuery struct + func NewHasParentQuery(parentType string, query Query) *HasParentQuery + func (q *HasParentQuery) Boost(boost float64) *HasParentQuery + func (q *HasParentQuery) InnerHit(innerHit *InnerHit) *HasParentQuery + func (q *HasParentQuery) QueryName(queryName string) *HasParentQuery + func (q *HasParentQuery) Score(score bool) *HasParentQuery + func (q *HasParentQuery) Source() (interface{}, error) + type Highlight struct + func NewHighlight() *Highlight + func (hl *Highlight) BoundaryChars(boundaryChars string) *Highlight + func (hl *Highlight) BoundaryMaxScan(boundaryMaxScan int) *Highlight + func (hl *Highlight) BoundaryScannerLocale(boundaryScannerLocale string) *Highlight + func (hl *Highlight) BoundaryScannerType(boundaryScannerType string) *Highlight + func (hl *Highlight) Encoder(encoder string) *Highlight + func (hl *Highlight) Field(name string) *Highlight + func (hl *Highlight) Fields(fields ...*HighlighterField) *Highlight + func (hl *Highlight) ForceSource(forceSource bool) *Highlight + func (hl *Highlight) FragmentSize(fragmentSize int) *Highlight + func (hl *Highlight) Fragmenter(fragmenter string) *Highlight + func (hl *Highlight) HighlighQuery(highlightQuery Query) *Highlight + func (hl *Highlight) HighlightFilter(highlightFilter bool) *Highlight + func (hl *Highlight) HighlighterType(highlighterType string) *Highlight + func (hl *Highlight) NoMatchSize(noMatchSize int) *Highlight + func (hl *Highlight) NumOfFragments(numOfFragments int) *Highlight + func (hl *Highlight) Options(options map[string]interface{}) *Highlight + func (hl *Highlight) Order(order string) *Highlight + func (hl *Highlight) PostTags(postTags ...string) *Highlight + func (hl *Highlight) PreTags(preTags ...string) *Highlight + func (hl *Highlight) RequireFieldMatch(requireFieldMatch bool) *Highlight + func (hl *Highlight) Source() (interface{}, error) + func (hl *Highlight) TagsSchema(schemaName string) *Highlight + func (hl *Highlight) UseExplicitFieldOrder(useExplicitFieldOrder bool) *Highlight + type HighlighterField struct + Name string + func NewHighlighterField(name string) *HighlighterField + func (f *HighlighterField) BoundaryChars(boundaryChars ...rune) *HighlighterField + func (f *HighlighterField) BoundaryMaxScan(boundaryMaxScan int) *HighlighterField + func (f *HighlighterField) ForceSource(forceSource bool) *HighlighterField + func (f *HighlighterField) FragmentOffset(fragmentOffset int) *HighlighterField + func (f *HighlighterField) FragmentSize(fragmentSize int) *HighlighterField + func (f *HighlighterField) Fragmenter(fragmenter string) *HighlighterField + func (f *HighlighterField) HighlightFilter(highlightFilter bool) *HighlighterField + func (f *HighlighterField) HighlightQuery(highlightQuery Query) *HighlighterField + func (f *HighlighterField) HighlighterType(highlighterType string) *HighlighterField + func (f *HighlighterField) MatchedFields(matchedFields ...string) *HighlighterField + func (f *HighlighterField) NoMatchSize(noMatchSize int) *HighlighterField + func (f *HighlighterField) NumOfFragments(numOfFragments int) *HighlighterField + func (f *HighlighterField) Options(options map[string]interface{}) *HighlighterField + func (f *HighlighterField) Order(order string) *HighlighterField + func (f *HighlighterField) PhraseLimit(phraseLimit int) *HighlighterField + func (f *HighlighterField) PostTags(postTags ...string) *HighlighterField + func (f *HighlighterField) PreTags(preTags ...string) *HighlighterField + func (f *HighlighterField) RequireFieldMatch(requireFieldMatch bool) *HighlighterField + func (f *HighlighterField) Source() (interface{}, error) + type HistogramAggregation struct + func NewHistogramAggregation() *HistogramAggregation + func (a *HistogramAggregation) ExtendedBounds(min, max float64) *HistogramAggregation + func (a *HistogramAggregation) ExtendedBoundsMax(max float64) *HistogramAggregation + func (a *HistogramAggregation) ExtendedBoundsMin(min float64) *HistogramAggregation + func (a *HistogramAggregation) Field(field string) *HistogramAggregation + func (a *HistogramAggregation) Interval(interval float64) *HistogramAggregation + func (a *HistogramAggregation) MaxBounds(max float64) *HistogramAggregation + func (a *HistogramAggregation) Meta(metaData map[string]interface{}) *HistogramAggregation + func (a *HistogramAggregation) MinBounds(min float64) *HistogramAggregation + func (a *HistogramAggregation) MinDocCount(minDocCount int64) *HistogramAggregation + func (a *HistogramAggregation) Missing(missing interface{}) *HistogramAggregation + func (a *HistogramAggregation) Offset(offset float64) *HistogramAggregation + func (a *HistogramAggregation) Order(order string, asc bool) *HistogramAggregation + func (a *HistogramAggregation) OrderByAggregation(aggName string, asc bool) *HistogramAggregation + func (a *HistogramAggregation) OrderByAggregationAndMetric(aggName, metric string, asc bool) *HistogramAggregation + func (a *HistogramAggregation) OrderByCount(asc bool) *HistogramAggregation + func (a *HistogramAggregation) OrderByCountAsc() *HistogramAggregation + func (a *HistogramAggregation) OrderByCountDesc() *HistogramAggregation + func (a *HistogramAggregation) OrderByKey(asc bool) *HistogramAggregation + func (a *HistogramAggregation) OrderByKeyAsc() *HistogramAggregation + func (a *HistogramAggregation) OrderByKeyDesc() *HistogramAggregation + func (a *HistogramAggregation) Script(script *Script) *HistogramAggregation + func (a *HistogramAggregation) Source() (interface{}, error) + func (a *HistogramAggregation) SubAggregation(name string, subAggregation Aggregation) *HistogramAggregation + type HoltLinearMovAvgModel struct + func NewHoltLinearMovAvgModel() *HoltLinearMovAvgModel + func (m *HoltLinearMovAvgModel) Alpha(alpha float64) *HoltLinearMovAvgModel + func (m *HoltLinearMovAvgModel) Beta(beta float64) *HoltLinearMovAvgModel + func (m *HoltLinearMovAvgModel) Name() string + func (m *HoltLinearMovAvgModel) Settings() map[string]interface{} + type HoltWintersMovAvgModel struct + func NewHoltWintersMovAvgModel() *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Alpha(alpha float64) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Beta(beta float64) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Gamma(gamma float64) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Name() string + func (m *HoltWintersMovAvgModel) Pad(pad bool) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Period(period int) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) SeasonalityType(typ string) *HoltWintersMovAvgModel + func (m *HoltWintersMovAvgModel) Settings() map[string]interface{} + type IPRangeAggregation struct + func NewIPRangeAggregation() *IPRangeAggregation + func (a *IPRangeAggregation) AddMaskRange(mask string) *IPRangeAggregation + func (a *IPRangeAggregation) AddMaskRangeWithKey(key, mask string) *IPRangeAggregation + func (a *IPRangeAggregation) AddRange(from, to string) *IPRangeAggregation + func (a *IPRangeAggregation) AddRangeWithKey(key, from, to string) *IPRangeAggregation + func (a *IPRangeAggregation) AddUnboundedFrom(to string) *IPRangeAggregation + func (a *IPRangeAggregation) AddUnboundedFromWithKey(key, to string) *IPRangeAggregation + func (a *IPRangeAggregation) AddUnboundedTo(from string) *IPRangeAggregation + func (a *IPRangeAggregation) AddUnboundedToWithKey(key, from string) *IPRangeAggregation + func (a *IPRangeAggregation) Between(from, to string) *IPRangeAggregation + func (a *IPRangeAggregation) BetweenWithKey(key, from, to string) *IPRangeAggregation + func (a *IPRangeAggregation) Field(field string) *IPRangeAggregation + func (a *IPRangeAggregation) Gt(from string) *IPRangeAggregation + func (a *IPRangeAggregation) GtWithKey(key, from string) *IPRangeAggregation + func (a *IPRangeAggregation) Keyed(keyed bool) *IPRangeAggregation + func (a *IPRangeAggregation) Lt(to string) *IPRangeAggregation + func (a *IPRangeAggregation) LtWithKey(key, to string) *IPRangeAggregation + func (a *IPRangeAggregation) Meta(metaData map[string]interface{}) *IPRangeAggregation + func (a *IPRangeAggregation) Source() (interface{}, error) + func (a *IPRangeAggregation) SubAggregation(name string, subAggregation Aggregation) *IPRangeAggregation + type IPRangeAggregationEntry struct + From string + Key string + Mask string + To string + type IdsQuery struct + func NewIdsQuery(types ...string) *IdsQuery + func (q *IdsQuery) Boost(boost float64) *IdsQuery + func (q *IdsQuery) Ids(ids ...string) *IdsQuery + func (q *IdsQuery) QueryName(queryName string) *IdsQuery + func (q *IdsQuery) Source() (interface{}, error) + type IndexResponse struct + ForcedRefresh bool + Id string + Index string + PrimaryTerm int64 + Result string + SeqNo int64 + Shards *shardsInfo + Status int + Type string + Version int64 + type IndexSegments struct + Shards map[string][]*IndexSegmentsShards + type IndexSegmentsDetails struct + Attributes map[string]string + Committed bool + Compound bool + DeletedDocs int64 + Generation int64 + Memory string + MemoryInBytes int64 + MergeId string + NumDocs int64 + RAMTree []*IndexSegmentsRamTree + Search bool + Size string + SizeInBytes int64 + Sort []*IndexSegmentsSort + Version string + type IndexSegmentsRamTree struct + Children []*IndexSegmentsRamTree + Description string + Size string + SizeInBytes int64 + type IndexSegmentsRouting struct + Node string + Primary bool + RelocatingNode string + State string + type IndexSegmentsShards struct + NumCommittedSegments int64 + NumSearchSegments int64 + Routing *IndexSegmentsRouting + Segments map[string]*IndexSegmentsDetails + type IndexSegmentsSort struct + Field string + Missing interface{} + Mode string + Reverse bool + type IndexService struct + func NewIndexService(client *Client) *IndexService + func (s *IndexService) BodyJson(body interface{}) *IndexService + func (s *IndexService) BodyString(body string) *IndexService + func (s *IndexService) Do(ctx context.Context) (*IndexResponse, error) + func (s *IndexService) Id(id string) *IndexService + func (s *IndexService) Index(index string) *IndexService + func (s *IndexService) OpType(opType string) *IndexService + func (s *IndexService) Parent(parent string) *IndexService + func (s *IndexService) Pipeline(pipeline string) *IndexService + func (s *IndexService) Pretty(pretty bool) *IndexService + func (s *IndexService) Refresh(refresh string) *IndexService + func (s *IndexService) Routing(routing string) *IndexService + func (s *IndexService) TTL(ttl string) *IndexService + func (s *IndexService) Timeout(timeout string) *IndexService + func (s *IndexService) Timestamp(timestamp string) *IndexService + func (s *IndexService) Ttl(ttl string) *IndexService + func (s *IndexService) Type(typ string) *IndexService + func (s *IndexService) Validate() error + func (s *IndexService) Version(version interface{}) *IndexService + func (s *IndexService) VersionType(versionType string) *IndexService + func (s *IndexService) WaitForActiveShards(waitForActiveShards string) *IndexService + type IndexStats struct + Primaries *IndexStatsDetails + Total *IndexStatsDetails + type IndexStatsCompletion struct + Size string + SizeInBytes int64 + type IndexStatsDetails struct + Completion *IndexStatsCompletion + Docs *IndexStatsDocs + Fielddata *IndexStatsFielddata + FilterCache *IndexStatsFilterCache + Flush *IndexStatsFlush + Get *IndexStatsGet + IdCache *IndexStatsIdCache + Indexing *IndexStatsIndexing + Merges *IndexStatsMerges + Percolate *IndexStatsPercolate + QueryCache *IndexStatsQueryCache + Refresh *IndexStatsRefresh + Search *IndexStatsSearch + Segments *IndexStatsSegments + Store *IndexStatsStore + Suggest *IndexStatsSuggest + Translog *IndexStatsTranslog + Warmer *IndexStatsWarmer + type IndexStatsDocs struct + Count int64 + Deleted int64 + type IndexStatsFielddata struct + Evictions int64 + MemorySize string + MemorySizeInBytes int64 + type IndexStatsFilterCache struct + Evictions int64 + MemorySize string + MemorySizeInBytes int64 + type IndexStatsFlush struct + Total int64 + TotalTime string + TotalTimeInMillis int64 + type IndexStatsGet struct + Current int64 + ExistsTime string + ExistsTimeInMillis int64 + ExistsTotal int64 + GetTime string + MissingTime string + MissingTimeInMillis int64 + MissingTotal int64 + TimeInMillis int64 + Total int64 + type IndexStatsIdCache struct + MemorySize string + MemorySizeInBytes int64 + type IndexStatsIndexing struct + DeleteCurrent int64 + DeleteTime string + DeleteTimeInMillis int64 + DeleteTotal int64 + IndexCurrent int64 + IndexTime string + IndexTimeInMillis int64 + IndexTotal int64 + NoopUpdateTotal int64 + type IndexStatsMerges struct + Current int64 + CurrentDocs int64 + CurrentSize string + CurrentSizeInBytes int64 + Total int64 + TotalDocs int64 + TotalSize string + TotalSizeInBytes int64 + TotalTime string + TotalTimeInMillis int64 + type IndexStatsPercolate struct + Current int64 + GetTime string + MemorySize string + MemorySizeInBytes int64 + Queries int64 + TimeInMillis int64 + Total int64 + type IndexStatsQueryCache struct + Evictions int64 + HitCount int64 + MemorySize string + MemorySizeInBytes int64 + MissCount int64 + type IndexStatsRefresh struct + Total int64 + TotalTime string + TotalTimeInMillis int64 + type IndexStatsSearch struct + FetchCurrent int64 + FetchTime string + FetchTimeInMillis int64 + FetchTotal int64 + OpenContexts int64 + QueryCurrent int64 + QueryTime string + QueryTimeInMillis int64 + QueryTotal int64 + type IndexStatsSegments struct + Count int64 + FixedBitSetMemory string + FixedBitSetMemoryInBytes int64 + IndexWriterMaxMemory string + IndexWriterMaxMemoryInBytes int64 + IndexWriterMemory string + IndexWriterMemoryInBytes int64 + Memory string + MemoryInBytes int64 + VersionMapMemory string + VersionMapMemoryInBytes int64 + type IndexStatsStore struct + Size string + SizeInBytes int64 + type IndexStatsSuggest struct + Current int64 + Time string + TimeInMillis int64 + Total int64 + type IndexStatsTranslog struct + Operations int64 + Size string + SizeInBytes int64 + type IndexStatsWarmer struct + Current int64 + Total int64 + TotalTime string + TotalTimeInMillis int64 + type IndicesAnalyzeRequest struct + Analyzer string + Attributes []string + CharFilter []string + Explain bool + Field string + Filter []string + Text []string + Tokenizer string + type IndicesAnalyzeResponse struct + Detail IndicesAnalyzeResponseDetail + Tokens []IndicesAnalyzeResponseToken + type IndicesAnalyzeResponseDetail struct + Analyzer struct{ ... } + Charfilters []interface{} + CustomAnalyzer bool + Tokenfilters []struct{ ... } + Tokenizer struct{ ... } + type IndicesAnalyzeResponseToken struct + EndOffset int + Position int + StartOffset int + Token string + Type string + type IndicesAnalyzeService struct + func NewIndicesAnalyzeService(client *Client) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Analyzer(analyzer string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Attributes(attributes ...string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) BodyJson(body interface{}) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) BodyString(body string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) CharFilter(charFilter ...string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Do(ctx context.Context) (*IndicesAnalyzeResponse, error) + func (s *IndicesAnalyzeService) Explain(explain bool) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Field(field string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Filter(filter ...string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Format(format string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Index(index string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) PreferLocal(preferLocal bool) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Pretty(pretty bool) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Request(request *IndicesAnalyzeRequest) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Text(text ...string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Tokenizer(tokenizer string) *IndicesAnalyzeService + func (s *IndicesAnalyzeService) Validate() error + type IndicesCloseResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesCloseService struct + func NewIndicesCloseService(client *Client) *IndicesCloseService + func (s *IndicesCloseService) AllowNoIndices(allowNoIndices bool) *IndicesCloseService + func (s *IndicesCloseService) Do(ctx context.Context) (*IndicesCloseResponse, error) + func (s *IndicesCloseService) ExpandWildcards(expandWildcards string) *IndicesCloseService + func (s *IndicesCloseService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesCloseService + func (s *IndicesCloseService) Index(index string) *IndicesCloseService + func (s *IndicesCloseService) MasterTimeout(masterTimeout string) *IndicesCloseService + func (s *IndicesCloseService) Pretty(pretty bool) *IndicesCloseService + func (s *IndicesCloseService) Timeout(timeout string) *IndicesCloseService + func (s *IndicesCloseService) Validate() error + type IndicesCreateResult struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesCreateService struct + func NewIndicesCreateService(client *Client) *IndicesCreateService + func (b *IndicesCreateService) Body(body string) *IndicesCreateService + func (b *IndicesCreateService) BodyJson(body interface{}) *IndicesCreateService + func (b *IndicesCreateService) BodyString(body string) *IndicesCreateService + func (b *IndicesCreateService) Do(ctx context.Context) (*IndicesCreateResult, error) + func (b *IndicesCreateService) Index(index string) *IndicesCreateService + func (b *IndicesCreateService) Pretty(pretty bool) *IndicesCreateService + func (s *IndicesCreateService) MasterTimeout(masterTimeout string) *IndicesCreateService + func (s *IndicesCreateService) Timeout(timeout string) *IndicesCreateService + type IndicesDeleteResponse struct + Acknowledged bool + type IndicesDeleteService struct + func NewIndicesDeleteService(client *Client) *IndicesDeleteService + func (s *IndicesDeleteService) Do(ctx context.Context) (*IndicesDeleteResponse, error) + func (s *IndicesDeleteService) Index(index []string) *IndicesDeleteService + func (s *IndicesDeleteService) MasterTimeout(masterTimeout string) *IndicesDeleteService + func (s *IndicesDeleteService) Pretty(pretty bool) *IndicesDeleteService + func (s *IndicesDeleteService) Timeout(timeout string) *IndicesDeleteService + func (s *IndicesDeleteService) Validate() error + type IndicesDeleteTemplateResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesDeleteTemplateService struct + func NewIndicesDeleteTemplateService(client *Client) *IndicesDeleteTemplateService + func (s *IndicesDeleteTemplateService) Do(ctx context.Context) (*IndicesDeleteTemplateResponse, error) + func (s *IndicesDeleteTemplateService) MasterTimeout(masterTimeout string) *IndicesDeleteTemplateService + func (s *IndicesDeleteTemplateService) Name(name string) *IndicesDeleteTemplateService + func (s *IndicesDeleteTemplateService) Pretty(pretty bool) *IndicesDeleteTemplateService + func (s *IndicesDeleteTemplateService) Timeout(timeout string) *IndicesDeleteTemplateService + func (s *IndicesDeleteTemplateService) Validate() error + type IndicesExistsService struct + func NewIndicesExistsService(client *Client) *IndicesExistsService + func (s *IndicesExistsService) AllowNoIndices(allowNoIndices bool) *IndicesExistsService + func (s *IndicesExistsService) Do(ctx context.Context) (bool, error) + func (s *IndicesExistsService) ExpandWildcards(expandWildcards string) *IndicesExistsService + func (s *IndicesExistsService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesExistsService + func (s *IndicesExistsService) Index(index []string) *IndicesExistsService + func (s *IndicesExistsService) Local(local bool) *IndicesExistsService + func (s *IndicesExistsService) Pretty(pretty bool) *IndicesExistsService + func (s *IndicesExistsService) Validate() error + type IndicesExistsTemplateService struct + func NewIndicesExistsTemplateService(client *Client) *IndicesExistsTemplateService + func (s *IndicesExistsTemplateService) Do(ctx context.Context) (bool, error) + func (s *IndicesExistsTemplateService) Local(local bool) *IndicesExistsTemplateService + func (s *IndicesExistsTemplateService) Name(name string) *IndicesExistsTemplateService + func (s *IndicesExistsTemplateService) Pretty(pretty bool) *IndicesExistsTemplateService + func (s *IndicesExistsTemplateService) Validate() error + type IndicesExistsTypeService struct + func NewIndicesExistsTypeService(client *Client) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) AllowNoIndices(allowNoIndices bool) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Do(ctx context.Context) (bool, error) + func (s *IndicesExistsTypeService) ExpandWildcards(expandWildcards string) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Index(indices ...string) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Local(local bool) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Pretty(pretty bool) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Type(types ...string) *IndicesExistsTypeService + func (s *IndicesExistsTypeService) Validate() error + type IndicesFlushResponse struct + Shards shardsInfo + type IndicesFlushService struct + func NewIndicesFlushService(client *Client) *IndicesFlushService + func (s *IndicesFlushService) AllowNoIndices(allowNoIndices bool) *IndicesFlushService + func (s *IndicesFlushService) Do(ctx context.Context) (*IndicesFlushResponse, error) + func (s *IndicesFlushService) ExpandWildcards(expandWildcards string) *IndicesFlushService + func (s *IndicesFlushService) Force(force bool) *IndicesFlushService + func (s *IndicesFlushService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesFlushService + func (s *IndicesFlushService) Index(indices ...string) *IndicesFlushService + func (s *IndicesFlushService) Pretty(pretty bool) *IndicesFlushService + func (s *IndicesFlushService) Validate() error + func (s *IndicesFlushService) WaitIfOngoing(waitIfOngoing bool) *IndicesFlushService + type IndicesForcemergeResponse struct + Shards shardsInfo + type IndicesForcemergeService struct + func NewIndicesForcemergeService(client *Client) *IndicesForcemergeService + func (s *IndicesForcemergeService) AllowNoIndices(allowNoIndices bool) *IndicesForcemergeService + func (s *IndicesForcemergeService) Do(ctx context.Context) (*IndicesForcemergeResponse, error) + func (s *IndicesForcemergeService) ExpandWildcards(expandWildcards string) *IndicesForcemergeService + func (s *IndicesForcemergeService) Flush(flush bool) *IndicesForcemergeService + func (s *IndicesForcemergeService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesForcemergeService + func (s *IndicesForcemergeService) Index(index ...string) *IndicesForcemergeService + func (s *IndicesForcemergeService) MaxNumSegments(maxNumSegments interface{}) *IndicesForcemergeService + func (s *IndicesForcemergeService) OnlyExpungeDeletes(onlyExpungeDeletes bool) *IndicesForcemergeService + func (s *IndicesForcemergeService) OperationThreading(operationThreading interface{}) *IndicesForcemergeService + func (s *IndicesForcemergeService) Pretty(pretty bool) *IndicesForcemergeService + func (s *IndicesForcemergeService) Validate() error + type IndicesGetFieldMappingService struct + func NewGetFieldMappingService(client *Client) *IndicesGetFieldMappingService + func NewIndicesGetFieldMappingService(client *Client) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) AllowNoIndices(allowNoIndices bool) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Do(ctx context.Context) (map[string]interface{}, error) + func (s *IndicesGetFieldMappingService) ExpandWildcards(expandWildcards string) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Field(fields ...string) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Index(indices ...string) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Local(local bool) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Pretty(pretty bool) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Type(types ...string) *IndicesGetFieldMappingService + func (s *IndicesGetFieldMappingService) Validate() error + type IndicesGetMappingService struct + func NewGetMappingService(client *Client) *IndicesGetMappingService + func NewIndicesGetMappingService(client *Client) *IndicesGetMappingService + func (s *IndicesGetMappingService) AllowNoIndices(allowNoIndices bool) *IndicesGetMappingService + func (s *IndicesGetMappingService) Do(ctx context.Context) (map[string]interface{}, error) + func (s *IndicesGetMappingService) ExpandWildcards(expandWildcards string) *IndicesGetMappingService + func (s *IndicesGetMappingService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesGetMappingService + func (s *IndicesGetMappingService) Index(indices ...string) *IndicesGetMappingService + func (s *IndicesGetMappingService) Local(local bool) *IndicesGetMappingService + func (s *IndicesGetMappingService) Pretty(pretty bool) *IndicesGetMappingService + func (s *IndicesGetMappingService) Type(types ...string) *IndicesGetMappingService + func (s *IndicesGetMappingService) Validate() error + type IndicesGetResponse struct + Aliases map[string]interface{} + Mappings map[string]interface{} + Settings map[string]interface{} + Warmers map[string]interface{} + type IndicesGetService struct + func NewIndicesGetService(client *Client) *IndicesGetService + func (s *IndicesGetService) AllowNoIndices(allowNoIndices bool) *IndicesGetService + func (s *IndicesGetService) Do(ctx context.Context) (map[string]*IndicesGetResponse, error) + func (s *IndicesGetService) ExpandWildcards(expandWildcards string) *IndicesGetService + func (s *IndicesGetService) Feature(features ...string) *IndicesGetService + func (s *IndicesGetService) Human(human bool) *IndicesGetService + func (s *IndicesGetService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesGetService + func (s *IndicesGetService) Index(indices ...string) *IndicesGetService + func (s *IndicesGetService) Local(local bool) *IndicesGetService + func (s *IndicesGetService) Pretty(pretty bool) *IndicesGetService + func (s *IndicesGetService) Validate() error + type IndicesGetSettingsResponse struct + Settings map[string]interface{} + type IndicesGetSettingsService struct + func NewIndicesGetSettingsService(client *Client) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) AllowNoIndices(allowNoIndices bool) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Do(ctx context.Context) (map[string]*IndicesGetSettingsResponse, error) + func (s *IndicesGetSettingsService) ExpandWildcards(expandWildcards string) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) FlatSettings(flatSettings bool) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Index(indices ...string) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Local(local bool) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Name(name ...string) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Pretty(pretty bool) *IndicesGetSettingsService + func (s *IndicesGetSettingsService) Validate() error + type IndicesGetTemplateResponse struct + Aliases map[string]interface{} + Mappings map[string]interface{} + Order int + Settings map[string]interface{} + Template string + Version int + type IndicesGetTemplateService struct + func NewIndicesGetTemplateService(client *Client) *IndicesGetTemplateService + func (s *IndicesGetTemplateService) Do(ctx context.Context) (map[string]*IndicesGetTemplateResponse, error) + func (s *IndicesGetTemplateService) FlatSettings(flatSettings bool) *IndicesGetTemplateService + func (s *IndicesGetTemplateService) Local(local bool) *IndicesGetTemplateService + func (s *IndicesGetTemplateService) Name(name ...string) *IndicesGetTemplateService + func (s *IndicesGetTemplateService) Pretty(pretty bool) *IndicesGetTemplateService + func (s *IndicesGetTemplateService) Validate() error + type IndicesOpenResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesOpenService struct + func NewIndicesOpenService(client *Client) *IndicesOpenService + func (s *IndicesOpenService) AllowNoIndices(allowNoIndices bool) *IndicesOpenService + func (s *IndicesOpenService) Do(ctx context.Context) (*IndicesOpenResponse, error) + func (s *IndicesOpenService) ExpandWildcards(expandWildcards string) *IndicesOpenService + func (s *IndicesOpenService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesOpenService + func (s *IndicesOpenService) Index(index string) *IndicesOpenService + func (s *IndicesOpenService) MasterTimeout(masterTimeout string) *IndicesOpenService + func (s *IndicesOpenService) Pretty(pretty bool) *IndicesOpenService + func (s *IndicesOpenService) Timeout(timeout string) *IndicesOpenService + func (s *IndicesOpenService) Validate() error + type IndicesPutMappingService struct + func NewIndicesPutMappingService(client *Client) *IndicesPutMappingService + func NewPutMappingService(client *Client) *IndicesPutMappingService + func (s *IndicesPutMappingService) AllowNoIndices(allowNoIndices bool) *IndicesPutMappingService + func (s *IndicesPutMappingService) BodyJson(mapping map[string]interface{}) *IndicesPutMappingService + func (s *IndicesPutMappingService) BodyString(mapping string) *IndicesPutMappingService + func (s *IndicesPutMappingService) Do(ctx context.Context) (*PutMappingResponse, error) + func (s *IndicesPutMappingService) ExpandWildcards(expandWildcards string) *IndicesPutMappingService + func (s *IndicesPutMappingService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesPutMappingService + func (s *IndicesPutMappingService) Index(indices ...string) *IndicesPutMappingService + func (s *IndicesPutMappingService) MasterTimeout(masterTimeout string) *IndicesPutMappingService + func (s *IndicesPutMappingService) Pretty(pretty bool) *IndicesPutMappingService + func (s *IndicesPutMappingService) Timeout(timeout string) *IndicesPutMappingService + func (s *IndicesPutMappingService) Type(typ string) *IndicesPutMappingService + func (s *IndicesPutMappingService) UpdateAllTypes(updateAllTypes bool) *IndicesPutMappingService + func (s *IndicesPutMappingService) Validate() error + type IndicesPutSettingsResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesPutSettingsService struct + func NewIndicesPutSettingsService(client *Client) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) AllowNoIndices(allowNoIndices bool) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) BodyJson(body interface{}) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) BodyString(body string) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) Do(ctx context.Context) (*IndicesPutSettingsResponse, error) + func (s *IndicesPutSettingsService) ExpandWildcards(expandWildcards string) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) FlatSettings(flatSettings bool) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) Index(indices ...string) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) MasterTimeout(masterTimeout string) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) Pretty(pretty bool) *IndicesPutSettingsService + func (s *IndicesPutSettingsService) Validate() error + type IndicesPutTemplateResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesPutTemplateService struct + func NewIndicesPutTemplateService(client *Client) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) BodyJson(body interface{}) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) BodyString(body string) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Cause(cause string) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Create(create bool) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Do(ctx context.Context) (*IndicesPutTemplateResponse, error) + func (s *IndicesPutTemplateService) FlatSettings(flatSettings bool) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) MasterTimeout(masterTimeout string) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Name(name string) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Order(order interface{}) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Pretty(pretty bool) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Timeout(timeout string) *IndicesPutTemplateService + func (s *IndicesPutTemplateService) Validate() error + func (s *IndicesPutTemplateService) Version(version int) *IndicesPutTemplateService + type IndicesRolloverResponse struct + Acknowledged bool + Conditions map[string]bool + DryRun bool + NewIndex string + OldIndex string + RolledOver bool + ShardsAcknowledged bool + type IndicesRolloverService struct + func NewIndicesRolloverService(client *Client) *IndicesRolloverService + func (s *IndicesRolloverService) AddCondition(name string, value interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) AddMapping(typ string, mapping interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) AddMaxIndexAgeCondition(time string) *IndicesRolloverService + func (s *IndicesRolloverService) AddMaxIndexDocsCondition(docs int64) *IndicesRolloverService + func (s *IndicesRolloverService) AddSetting(name string, value interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) Alias(alias string) *IndicesRolloverService + func (s *IndicesRolloverService) BodyJson(body interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) BodyString(body string) *IndicesRolloverService + func (s *IndicesRolloverService) Conditions(conditions map[string]interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) Do(ctx context.Context) (*IndicesRolloverResponse, error) + func (s *IndicesRolloverService) DryRun(dryRun bool) *IndicesRolloverService + func (s *IndicesRolloverService) Mappings(mappings map[string]interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) MasterTimeout(masterTimeout string) *IndicesRolloverService + func (s *IndicesRolloverService) NewIndex(newIndex string) *IndicesRolloverService + func (s *IndicesRolloverService) Pretty(pretty bool) *IndicesRolloverService + func (s *IndicesRolloverService) Settings(settings map[string]interface{}) *IndicesRolloverService + func (s *IndicesRolloverService) Timeout(timeout string) *IndicesRolloverService + func (s *IndicesRolloverService) Validate() error + func (s *IndicesRolloverService) WaitForActiveShards(waitForActiveShards string) *IndicesRolloverService + type IndicesSegmentsResponse struct + Indices map[string]*IndexSegments + Shards shardsInfo + type IndicesSegmentsService struct + func NewIndicesSegmentsService(client *Client) *IndicesSegmentsService + func (s *IndicesSegmentsService) AllowNoIndices(allowNoIndices bool) *IndicesSegmentsService + func (s *IndicesSegmentsService) Do(ctx context.Context) (*IndicesSegmentsResponse, error) + func (s *IndicesSegmentsService) ExpandWildcards(expandWildcards string) *IndicesSegmentsService + func (s *IndicesSegmentsService) Human(human bool) *IndicesSegmentsService + func (s *IndicesSegmentsService) IgnoreUnavailable(ignoreUnavailable bool) *IndicesSegmentsService + func (s *IndicesSegmentsService) Index(indices ...string) *IndicesSegmentsService + func (s *IndicesSegmentsService) OperationThreading(operationThreading interface{}) *IndicesSegmentsService + func (s *IndicesSegmentsService) Pretty(pretty bool) *IndicesSegmentsService + func (s *IndicesSegmentsService) Validate() error + func (s *IndicesSegmentsService) Verbose(verbose bool) *IndicesSegmentsService + type IndicesShrinkResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IndicesShrinkService struct + func NewIndicesShrinkService(client *Client) *IndicesShrinkService + func (s *IndicesShrinkService) BodyJson(body interface{}) *IndicesShrinkService + func (s *IndicesShrinkService) BodyString(body string) *IndicesShrinkService + func (s *IndicesShrinkService) Do(ctx context.Context) (*IndicesShrinkResponse, error) + func (s *IndicesShrinkService) MasterTimeout(masterTimeout string) *IndicesShrinkService + func (s *IndicesShrinkService) Pretty(pretty bool) *IndicesShrinkService + func (s *IndicesShrinkService) Source(source string) *IndicesShrinkService + func (s *IndicesShrinkService) Target(target string) *IndicesShrinkService + func (s *IndicesShrinkService) Timeout(timeout string) *IndicesShrinkService + func (s *IndicesShrinkService) Validate() error + func (s *IndicesShrinkService) WaitForActiveShards(waitForActiveShards string) *IndicesShrinkService + type IndicesStatsResponse struct + All *IndexStats + Indices map[string]*IndexStats + Shards shardsInfo + type IndicesStatsService struct + func NewIndicesStatsService(client *Client) *IndicesStatsService + func (s *IndicesStatsService) CompletionFields(completionFields ...string) *IndicesStatsService + func (s *IndicesStatsService) Do(ctx context.Context) (*IndicesStatsResponse, error) + func (s *IndicesStatsService) FielddataFields(fielddataFields ...string) *IndicesStatsService + func (s *IndicesStatsService) Fields(fields ...string) *IndicesStatsService + func (s *IndicesStatsService) Groups(groups ...string) *IndicesStatsService + func (s *IndicesStatsService) Human(human bool) *IndicesStatsService + func (s *IndicesStatsService) Index(indices ...string) *IndicesStatsService + func (s *IndicesStatsService) Level(level string) *IndicesStatsService + func (s *IndicesStatsService) Metric(metric ...string) *IndicesStatsService + func (s *IndicesStatsService) Pretty(pretty bool) *IndicesStatsService + func (s *IndicesStatsService) Type(types ...string) *IndicesStatsService + func (s *IndicesStatsService) Validate() error + type IngestDeletePipelineResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IngestDeletePipelineService struct + func NewIngestDeletePipelineService(client *Client) *IngestDeletePipelineService + func (s *IngestDeletePipelineService) Do(ctx context.Context) (*IngestDeletePipelineResponse, error) + func (s *IngestDeletePipelineService) Id(id string) *IngestDeletePipelineService + func (s *IngestDeletePipelineService) MasterTimeout(masterTimeout string) *IngestDeletePipelineService + func (s *IngestDeletePipelineService) Pretty(pretty bool) *IngestDeletePipelineService + func (s *IngestDeletePipelineService) Timeout(timeout string) *IngestDeletePipelineService + func (s *IngestDeletePipelineService) Validate() error + type IngestGetPipeline struct + Config map[string]interface{} + ID string + type IngestGetPipelineResponse map[string]*IngestGetPipeline + type IngestGetPipelineService struct + func NewIngestGetPipelineService(client *Client) *IngestGetPipelineService + func (s *IngestGetPipelineService) Do(ctx context.Context) (IngestGetPipelineResponse, error) + func (s *IngestGetPipelineService) Id(id ...string) *IngestGetPipelineService + func (s *IngestGetPipelineService) MasterTimeout(masterTimeout string) *IngestGetPipelineService + func (s *IngestGetPipelineService) Pretty(pretty bool) *IngestGetPipelineService + func (s *IngestGetPipelineService) Validate() error + type IngestPutPipelineResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type IngestPutPipelineService struct + func NewIngestPutPipelineService(client *Client) *IngestPutPipelineService + func (s *IngestPutPipelineService) BodyJson(body interface{}) *IngestPutPipelineService + func (s *IngestPutPipelineService) BodyString(body string) *IngestPutPipelineService + func (s *IngestPutPipelineService) Do(ctx context.Context) (*IngestPutPipelineResponse, error) + func (s *IngestPutPipelineService) Id(id string) *IngestPutPipelineService + func (s *IngestPutPipelineService) MasterTimeout(masterTimeout string) *IngestPutPipelineService + func (s *IngestPutPipelineService) Pretty(pretty bool) *IngestPutPipelineService + func (s *IngestPutPipelineService) Timeout(timeout string) *IngestPutPipelineService + func (s *IngestPutPipelineService) Validate() error + type IngestSimulateDocumentResult struct + Doc map[string]interface{} + ProcessorResults []*IngestSimulateProcessorResult + type IngestSimulatePipelineResponse struct + Docs []*IngestSimulateDocumentResult + type IngestSimulatePipelineService struct + func NewIngestSimulatePipelineService(client *Client) *IngestSimulatePipelineService + func (s *IngestSimulatePipelineService) BodyJson(body interface{}) *IngestSimulatePipelineService + func (s *IngestSimulatePipelineService) BodyString(body string) *IngestSimulatePipelineService + func (s *IngestSimulatePipelineService) Do(ctx context.Context) (*IngestSimulatePipelineResponse, error) + func (s *IngestSimulatePipelineService) Id(id string) *IngestSimulatePipelineService + func (s *IngestSimulatePipelineService) Pretty(pretty bool) *IngestSimulatePipelineService + func (s *IngestSimulatePipelineService) Validate() error + func (s *IngestSimulatePipelineService) Verbose(verbose bool) *IngestSimulatePipelineService + type IngestSimulateProcessorResult struct + Doc map[string]interface{} + ProcessorTag string + type InnerHit struct + func NewInnerHit() *InnerHit + func (hit *InnerHit) DocvalueField(docvalueField string) *InnerHit + func (hit *InnerHit) DocvalueFields(docvalueFields ...string) *InnerHit + func (hit *InnerHit) Explain(explain bool) *InnerHit + func (hit *InnerHit) FetchSource(fetchSource bool) *InnerHit + func (hit *InnerHit) FetchSourceContext(fetchSourceContext *FetchSourceContext) *InnerHit + func (hit *InnerHit) From(from int) *InnerHit + func (hit *InnerHit) Highlight(highlight *Highlight) *InnerHit + func (hit *InnerHit) Highlighter() *Highlight + func (hit *InnerHit) Name(name string) *InnerHit + func (hit *InnerHit) NoStoredFields() *InnerHit + func (hit *InnerHit) Path(path string) *InnerHit + func (hit *InnerHit) Query(query Query) *InnerHit + func (hit *InnerHit) ScriptField(scriptField *ScriptField) *InnerHit + func (hit *InnerHit) ScriptFields(scriptFields ...*ScriptField) *InnerHit + func (hit *InnerHit) Size(size int) *InnerHit + func (hit *InnerHit) Sort(field string, ascending bool) *InnerHit + func (hit *InnerHit) SortBy(sorter ...Sorter) *InnerHit + func (hit *InnerHit) SortWithInfo(info SortInfo) *InnerHit + func (hit *InnerHit) Source() (interface{}, error) + func (hit *InnerHit) StoredField(storedFieldName string) *InnerHit + func (hit *InnerHit) StoredFields(storedFieldNames ...string) *InnerHit + func (hit *InnerHit) TrackScores(trackScores bool) *InnerHit + func (hit *InnerHit) Type(typ string) *InnerHit + func (hit *InnerHit) Version(version bool) *InnerHit + type JLHScoreSignificanceHeuristic struct + func NewJLHScoreSignificanceHeuristic() *JLHScoreSignificanceHeuristic + func (sh *JLHScoreSignificanceHeuristic) Name() string + func (sh *JLHScoreSignificanceHeuristic) Source() (interface{}, error) + type LaplaceSmoothingModel struct + func NewLaplaceSmoothingModel(alpha float64) *LaplaceSmoothingModel + func (sm *LaplaceSmoothingModel) Source() (interface{}, error) + func (sm *LaplaceSmoothingModel) Type() string + type LinearDecayFunction struct + func NewLinearDecayFunction() *LinearDecayFunction + func (fn *LinearDecayFunction) Decay(decay float64) *LinearDecayFunction + func (fn *LinearDecayFunction) FieldName(fieldName string) *LinearDecayFunction + func (fn *LinearDecayFunction) GetMultiValueMode() string + func (fn *LinearDecayFunction) GetWeight() *float64 + func (fn *LinearDecayFunction) MultiValueMode(mode string) *LinearDecayFunction + func (fn *LinearDecayFunction) Name() string + func (fn *LinearDecayFunction) Offset(offset interface{}) *LinearDecayFunction + func (fn *LinearDecayFunction) Origin(origin interface{}) *LinearDecayFunction + func (fn *LinearDecayFunction) Scale(scale interface{}) *LinearDecayFunction + func (fn *LinearDecayFunction) Source() (interface{}, error) + func (fn *LinearDecayFunction) Weight(weight float64) *LinearDecayFunction + type LinearInterpolationSmoothingModel struct + func NewLinearInterpolationSmoothingModel(trigramLamda, bigramLambda, unigramLambda float64) *LinearInterpolationSmoothingModel + func (sm *LinearInterpolationSmoothingModel) Source() (interface{}, error) + func (sm *LinearInterpolationSmoothingModel) Type() string + type LinearMovAvgModel struct + func NewLinearMovAvgModel() *LinearMovAvgModel + func (m *LinearMovAvgModel) Name() string + func (m *LinearMovAvgModel) Settings() map[string]interface{} + type Logger interface + Printf func(ctx context.Context, format string, v ...interface{}) + type MatchAllQuery struct + func NewMatchAllQuery() *MatchAllQuery + func (q *MatchAllQuery) Boost(boost float64) *MatchAllQuery + func (q *MatchAllQuery) QueryName(name string) *MatchAllQuery + func (q MatchAllQuery) Source() (interface{}, error) + type MatchNoneQuery struct + func NewMatchNoneQuery() *MatchNoneQuery + func (q *MatchNoneQuery) QueryName(name string) *MatchNoneQuery + func (q MatchNoneQuery) Source() (interface{}, error) + type MatchPhrasePrefixQuery struct + func NewMatchPhrasePrefixQuery(name string, value interface{}) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) Analyzer(analyzer string) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) Boost(boost float64) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) MaxExpansions(n int) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) QueryName(queryName string) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) Slop(slop int) *MatchPhrasePrefixQuery + func (q *MatchPhrasePrefixQuery) Source() (interface{}, error) + type MatchPhraseQuery struct + func NewMatchPhraseQuery(name string, value interface{}) *MatchPhraseQuery + func (q *MatchPhraseQuery) Analyzer(analyzer string) *MatchPhraseQuery + func (q *MatchPhraseQuery) Boost(boost float64) *MatchPhraseQuery + func (q *MatchPhraseQuery) QueryName(queryName string) *MatchPhraseQuery + func (q *MatchPhraseQuery) Slop(slop int) *MatchPhraseQuery + func (q *MatchPhraseQuery) Source() (interface{}, error) + type MatchQuery struct + func NewMatchQuery(name string, text interface{}) *MatchQuery + func (q *MatchQuery) Analyzer(analyzer string) *MatchQuery + func (q *MatchQuery) Boost(boost float64) *MatchQuery + func (q *MatchQuery) CutoffFrequency(cutoff float64) *MatchQuery + func (q *MatchQuery) Fuzziness(fuzziness string) *MatchQuery + func (q *MatchQuery) FuzzyRewrite(fuzzyRewrite string) *MatchQuery + func (q *MatchQuery) FuzzyTranspositions(fuzzyTranspositions bool) *MatchQuery + func (q *MatchQuery) Lenient(lenient bool) *MatchQuery + func (q *MatchQuery) MaxExpansions(maxExpansions int) *MatchQuery + func (q *MatchQuery) MinimumShouldMatch(minimumShouldMatch string) *MatchQuery + func (q *MatchQuery) Operator(operator string) *MatchQuery + func (q *MatchQuery) PrefixLength(prefixLength int) *MatchQuery + func (q *MatchQuery) QueryName(queryName string) *MatchQuery + func (q *MatchQuery) Source() (interface{}, error) + func (q *MatchQuery) ZeroTermsQuery(zeroTermsQuery string) *MatchQuery + type MatrixStatsAggregation struct + func NewMatrixStatsAggregation() *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Fields(fields ...string) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Format(format string) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Meta(metaData map[string]interface{}) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Missing(missing interface{}) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Mode(mode string) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) Source() (interface{}, error) + func (a *MatrixStatsAggregation) SubAggregation(name string, subAggregation Aggregation) *MatrixStatsAggregation + func (a *MatrixStatsAggregation) ValueType(valueType interface{}) *MatrixStatsAggregation + type MaxAggregation struct + func NewMaxAggregation() *MaxAggregation + func (a *MaxAggregation) Field(field string) *MaxAggregation + func (a *MaxAggregation) Format(format string) *MaxAggregation + func (a *MaxAggregation) Meta(metaData map[string]interface{}) *MaxAggregation + func (a *MaxAggregation) Script(script *Script) *MaxAggregation + func (a *MaxAggregation) Source() (interface{}, error) + func (a *MaxAggregation) SubAggregation(name string, subAggregation Aggregation) *MaxAggregation + type MaxBucketAggregation struct + func NewMaxBucketAggregation() *MaxBucketAggregation + func (a *MaxBucketAggregation) BucketsPath(bucketsPaths ...string) *MaxBucketAggregation + func (a *MaxBucketAggregation) Format(format string) *MaxBucketAggregation + func (a *MaxBucketAggregation) GapInsertZeros() *MaxBucketAggregation + func (a *MaxBucketAggregation) GapPolicy(gapPolicy string) *MaxBucketAggregation + func (a *MaxBucketAggregation) GapSkip() *MaxBucketAggregation + func (a *MaxBucketAggregation) Meta(metaData map[string]interface{}) *MaxBucketAggregation + func (a *MaxBucketAggregation) Source() (interface{}, error) + type MgetResponse struct + Docs []*GetResult + type MgetService struct + func NewMgetService(client *Client) *MgetService + func (s *MgetService) Add(items ...*MultiGetItem) *MgetService + func (s *MgetService) Do(ctx context.Context) (*MgetResponse, error) + func (s *MgetService) Preference(preference string) *MgetService + func (s *MgetService) Pretty(pretty bool) *MgetService + func (s *MgetService) Realtime(realtime bool) *MgetService + func (s *MgetService) Refresh(refresh string) *MgetService + func (s *MgetService) Routing(routing string) *MgetService + func (s *MgetService) Source() (interface{}, error) + func (s *MgetService) StoredFields(storedFields ...string) *MgetService + type MinAggregation struct + func NewMinAggregation() *MinAggregation + func (a *MinAggregation) Field(field string) *MinAggregation + func (a *MinAggregation) Format(format string) *MinAggregation + func (a *MinAggregation) Meta(metaData map[string]interface{}) *MinAggregation + func (a *MinAggregation) Script(script *Script) *MinAggregation + func (a *MinAggregation) Source() (interface{}, error) + func (a *MinAggregation) SubAggregation(name string, subAggregation Aggregation) *MinAggregation + type MinBucketAggregation struct + func NewMinBucketAggregation() *MinBucketAggregation + func (a *MinBucketAggregation) BucketsPath(bucketsPaths ...string) *MinBucketAggregation + func (a *MinBucketAggregation) Format(format string) *MinBucketAggregation + func (a *MinBucketAggregation) GapInsertZeros() *MinBucketAggregation + func (a *MinBucketAggregation) GapPolicy(gapPolicy string) *MinBucketAggregation + func (a *MinBucketAggregation) GapSkip() *MinBucketAggregation + func (a *MinBucketAggregation) Meta(metaData map[string]interface{}) *MinBucketAggregation + func (a *MinBucketAggregation) Source() (interface{}, error) + type MissingAggregation struct + func NewMissingAggregation() *MissingAggregation + func (a *MissingAggregation) Field(field string) *MissingAggregation + func (a *MissingAggregation) Meta(metaData map[string]interface{}) *MissingAggregation + func (a *MissingAggregation) Source() (interface{}, error) + func (a *MissingAggregation) SubAggregation(name string, subAggregation Aggregation) *MissingAggregation + type MoreLikeThisQuery struct + func NewMoreLikeThisQuery() *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Analyzer(analyzer string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Boost(boost float64) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) BoostTerms(boostTerms float64) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) FailOnUnsupportedField(fail bool) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Field(fields ...string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Ids(ids ...string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) IgnoreLikeItems(ignoreDocs ...*MoreLikeThisQueryItem) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) IgnoreLikeText(ignoreLikeText ...string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Include(include bool) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) LikeItems(docs ...*MoreLikeThisQueryItem) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) LikeText(likeTexts ...string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MaxDocFreq(maxDocFreq int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MaxQueryTerms(maxQueryTerms int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MaxWordLength(maxWordLength int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MinDocFreq(minDocFreq int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MinTermFreq(minTermFreq int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MinWordLength(minWordLength int) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) MinimumShouldMatch(minimumShouldMatch string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) QueryName(queryName string) *MoreLikeThisQuery + func (q *MoreLikeThisQuery) Source() (interface{}, error) + func (q *MoreLikeThisQuery) StopWord(stopWords ...string) *MoreLikeThisQuery + type MoreLikeThisQueryItem struct + func NewMoreLikeThisQueryItem() *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Doc(doc interface{}) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) FetchSourceContext(fsc *FetchSourceContext) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Fields(fields ...string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Id(id string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Index(index string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) LikeText(likeText string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Routing(routing string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Source() (interface{}, error) + func (item *MoreLikeThisQueryItem) Type(typ string) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) Version(version int64) *MoreLikeThisQueryItem + func (item *MoreLikeThisQueryItem) VersionType(versionType string) *MoreLikeThisQueryItem + type MovAvgAggregation struct + func NewMovAvgAggregation() *MovAvgAggregation + func (a *MovAvgAggregation) BucketsPath(bucketsPaths ...string) *MovAvgAggregation + func (a *MovAvgAggregation) Format(format string) *MovAvgAggregation + func (a *MovAvgAggregation) GapInsertZeros() *MovAvgAggregation + func (a *MovAvgAggregation) GapPolicy(gapPolicy string) *MovAvgAggregation + func (a *MovAvgAggregation) GapSkip() *MovAvgAggregation + func (a *MovAvgAggregation) Meta(metaData map[string]interface{}) *MovAvgAggregation + func (a *MovAvgAggregation) Minimize(minimize bool) *MovAvgAggregation + func (a *MovAvgAggregation) Model(model MovAvgModel) *MovAvgAggregation + func (a *MovAvgAggregation) Predict(numPredictions int) *MovAvgAggregation + func (a *MovAvgAggregation) Source() (interface{}, error) + func (a *MovAvgAggregation) Window(window int) *MovAvgAggregation + type MovAvgModel interface + Name func() string + Settings func() map[string]interface{} + type MultiGetItem struct + func NewMultiGetItem() *MultiGetItem + func (item *MultiGetItem) FetchSource(fetchSourceContext *FetchSourceContext) *MultiGetItem + func (item *MultiGetItem) Id(id string) *MultiGetItem + func (item *MultiGetItem) Index(index string) *MultiGetItem + func (item *MultiGetItem) Routing(routing string) *MultiGetItem + func (item *MultiGetItem) Source() (interface{}, error) + func (item *MultiGetItem) StoredFields(storedFields ...string) *MultiGetItem + func (item *MultiGetItem) Type(typ string) *MultiGetItem + func (item *MultiGetItem) Version(version int64) *MultiGetItem + func (item *MultiGetItem) VersionType(versionType string) *MultiGetItem + type MultiMatchQuery struct + func NewMultiMatchQuery(text interface{}, fields ...string) *MultiMatchQuery + func (q *MultiMatchQuery) Analyzer(analyzer string) *MultiMatchQuery + func (q *MultiMatchQuery) Boost(boost float64) *MultiMatchQuery + func (q *MultiMatchQuery) CutoffFrequency(cutoff float64) *MultiMatchQuery + func (q *MultiMatchQuery) Field(field string) *MultiMatchQuery + func (q *MultiMatchQuery) FieldWithBoost(field string, boost float64) *MultiMatchQuery + func (q *MultiMatchQuery) Fuzziness(fuzziness string) *MultiMatchQuery + func (q *MultiMatchQuery) FuzzyRewrite(fuzzyRewrite string) *MultiMatchQuery + func (q *MultiMatchQuery) Lenient(lenient bool) *MultiMatchQuery + func (q *MultiMatchQuery) MaxExpansions(maxExpansions int) *MultiMatchQuery + func (q *MultiMatchQuery) MinimumShouldMatch(minimumShouldMatch string) *MultiMatchQuery + func (q *MultiMatchQuery) Operator(operator string) *MultiMatchQuery + func (q *MultiMatchQuery) PrefixLength(prefixLength int) *MultiMatchQuery + func (q *MultiMatchQuery) QueryName(queryName string) *MultiMatchQuery + func (q *MultiMatchQuery) Rewrite(rewrite string) *MultiMatchQuery + func (q *MultiMatchQuery) Slop(slop int) *MultiMatchQuery + func (q *MultiMatchQuery) Source() (interface{}, error) + func (q *MultiMatchQuery) TieBreaker(tieBreaker float64) *MultiMatchQuery + func (q *MultiMatchQuery) Type(typ string) *MultiMatchQuery + func (q *MultiMatchQuery) ZeroTermsQuery(zeroTermsQuery string) *MultiMatchQuery + type MultiSearchResult struct + Responses []*SearchResult + type MultiSearchService struct + func NewMultiSearchService(client *Client) *MultiSearchService + func (s *MultiSearchService) Add(requests ...*SearchRequest) *MultiSearchService + func (s *MultiSearchService) Do(ctx context.Context) (*MultiSearchResult, error) + func (s *MultiSearchService) Index(indices ...string) *MultiSearchService + func (s *MultiSearchService) MaxConcurrentSearches(max int) *MultiSearchService + func (s *MultiSearchService) PreFilterShardSize(size int) *MultiSearchService + func (s *MultiSearchService) Pretty(pretty bool) *MultiSearchService + type MultiTermvectorItem struct + func NewMultiTermvectorItem() *MultiTermvectorItem + func (s *MultiTermvectorItem) Doc(doc interface{}) *MultiTermvectorItem + func (s *MultiTermvectorItem) FieldStatistics(fieldStatistics bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) Fields(fields ...string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Id(id string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Index(index string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Offsets(offsets bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) Parent(parent string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Payloads(payloads bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) PerFieldAnalyzer(perFieldAnalyzer map[string]string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Positions(positions bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) Preference(preference string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Realtime(realtime bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) Routing(routing string) *MultiTermvectorItem + func (s *MultiTermvectorItem) Source() interface{} + func (s *MultiTermvectorItem) TermStatistics(termStatistics bool) *MultiTermvectorItem + func (s *MultiTermvectorItem) Type(typ string) *MultiTermvectorItem + type MultiTermvectorResponse struct + Docs []*TermvectorsResponse + type MultiTermvectorService struct + func NewMultiTermvectorService(client *Client) *MultiTermvectorService + func (s *MultiTermvectorService) Add(docs ...*MultiTermvectorItem) *MultiTermvectorService + func (s *MultiTermvectorService) BodyJson(body interface{}) *MultiTermvectorService + func (s *MultiTermvectorService) BodyString(body string) *MultiTermvectorService + func (s *MultiTermvectorService) Do(ctx context.Context) (*MultiTermvectorResponse, error) + func (s *MultiTermvectorService) FieldStatistics(fieldStatistics bool) *MultiTermvectorService + func (s *MultiTermvectorService) Fields(fields []string) *MultiTermvectorService + func (s *MultiTermvectorService) Ids(ids []string) *MultiTermvectorService + func (s *MultiTermvectorService) Index(index string) *MultiTermvectorService + func (s *MultiTermvectorService) Offsets(offsets bool) *MultiTermvectorService + func (s *MultiTermvectorService) Parent(parent string) *MultiTermvectorService + func (s *MultiTermvectorService) Payloads(payloads bool) *MultiTermvectorService + func (s *MultiTermvectorService) Positions(positions bool) *MultiTermvectorService + func (s *MultiTermvectorService) Preference(preference string) *MultiTermvectorService + func (s *MultiTermvectorService) Pretty(pretty bool) *MultiTermvectorService + func (s *MultiTermvectorService) Realtime(realtime bool) *MultiTermvectorService + func (s *MultiTermvectorService) Routing(routing string) *MultiTermvectorService + func (s *MultiTermvectorService) Source() interface{} + func (s *MultiTermvectorService) TermStatistics(termStatistics bool) *MultiTermvectorService + func (s *MultiTermvectorService) Type(typ string) *MultiTermvectorService + func (s *MultiTermvectorService) Validate() error + func (s *MultiTermvectorService) Version(version interface{}) *MultiTermvectorService + func (s *MultiTermvectorService) VersionType(versionType string) *MultiTermvectorService + type MutualInformationSignificanceHeuristic struct + func NewMutualInformationSignificanceHeuristic() *MutualInformationSignificanceHeuristic + func (sh *MutualInformationSignificanceHeuristic) BackgroundIsSuperset(backgroundIsSuperset bool) *MutualInformationSignificanceHeuristic + func (sh *MutualInformationSignificanceHeuristic) IncludeNegatives(includeNegatives bool) *MutualInformationSignificanceHeuristic + func (sh *MutualInformationSignificanceHeuristic) Name() string + func (sh *MutualInformationSignificanceHeuristic) Source() (interface{}, error) + type NestedAggregation struct + func NewNestedAggregation() *NestedAggregation + func (a *NestedAggregation) Meta(metaData map[string]interface{}) *NestedAggregation + func (a *NestedAggregation) Path(path string) *NestedAggregation + func (a *NestedAggregation) Source() (interface{}, error) + func (a *NestedAggregation) SubAggregation(name string, subAggregation Aggregation) *NestedAggregation + type NestedHit struct + Field string + Offset int + type NestedQuery struct + func NewNestedQuery(path string, query Query) *NestedQuery + func (q *NestedQuery) Boost(boost float64) *NestedQuery + func (q *NestedQuery) IgnoreUnmapped(value bool) *NestedQuery + func (q *NestedQuery) InnerHit(innerHit *InnerHit) *NestedQuery + func (q *NestedQuery) QueryName(queryName string) *NestedQuery + func (q *NestedQuery) ScoreMode(scoreMode string) *NestedQuery + func (q *NestedQuery) Source() (interface{}, error) + type NestedSort struct + func NewNestedSort(path string) *NestedSort + func (s *NestedSort) Filter(filter Query) *NestedSort + func (s *NestedSort) NestedSort(nestedSort *NestedSort) *NestedSort + func (s *NestedSort) Source() (interface{}, error) + type NodesInfoNode struct + Attributes map[string]string + BuildHash string + HTTP *NodesInfoNodeHTTP + Host string + IP string + Ingest *NodesInfoNodeIngest + JVM *NodesInfoNodeJVM + Modules []*NodesInfoNodeModule + Name string + OS *NodesInfoNodeOS + Plugins []*NodesInfoNodePlugin + Process *NodesInfoNodeProcess + Roles []string + Settings map[string]interface{} + ThreadPool *NodesInfoNodeThreadPool + TotalIndexingBuffer int64 + TotalIndexingBufferInBytes string + Transport *NodesInfoNodeTransport + TransportAddress string + Version string + func (n *NodesInfoNode) HasRole(role string) bool + func (n *NodesInfoNode) IsData() bool + func (n *NodesInfoNode) IsIngest() bool + func (n *NodesInfoNode) IsMaster() bool + type NodesInfoNodeHTTP struct + BoundAddress []string + MaxContentLength string + MaxContentLengthInBytes int64 + PublishAddress string + type NodesInfoNodeIngest struct + Processors []*NodesInfoNodeIngestProcessorInfo + type NodesInfoNodeIngestProcessorInfo struct + Type string + type NodesInfoNodeJVM struct + GCCollectors []string + InputArguments []string + Mem struct{ ... } + MemoryPools []string + PID int + StartTime time.Time + StartTimeInMillis int64 + UsingCompressedOrdinaryObjectPointers interface{} + VMName string + VMVendor string + VMVersion string + Version string + type NodesInfoNodeModule struct + Classname string + Description string + ElasticsearchVersion string + ExtendedPlugins []string + HasNativeController bool + JavaVersion string + Name string + RequiresKeystore bool + Version string + type NodesInfoNodeOS struct + AllocatedProcessors int + Arch string + AvailableProcessors int + Name string + RefreshInterval string + RefreshIntervalInMillis int + Version string + type NodesInfoNodePlugin struct + Classname string + Description string + ElasticsearchVersion string + ExtendedPlugins []string + HasNativeController bool + JavaVersion string + Name string + RequiresKeystore bool + Version string + type NodesInfoNodeProcess struct + ID int + Mlockall bool + RefreshInterval string + RefreshIntervalInMillis int64 + type NodesInfoNodeThreadPool struct + Bench *NodesInfoNodeThreadPoolSection + Bulk *NodesInfoNodeThreadPoolSection + FetchShardStarted *NodesInfoNodeThreadPoolSection + FetchShardStore *NodesInfoNodeThreadPoolSection + Flush *NodesInfoNodeThreadPoolSection + ForceMerge *NodesInfoNodeThreadPoolSection + Generic *NodesInfoNodeThreadPoolSection + Get *NodesInfoNodeThreadPoolSection + Index *NodesInfoNodeThreadPoolSection + Listener *NodesInfoNodeThreadPoolSection + Management *NodesInfoNodeThreadPoolSection + Merge *NodesInfoNodeThreadPoolSection + Optimize *NodesInfoNodeThreadPoolSection + Percolate *NodesInfoNodeThreadPoolSection + Refresh *NodesInfoNodeThreadPoolSection + Search *NodesInfoNodeThreadPoolSection + Snapshot *NodesInfoNodeThreadPoolSection + Suggest *NodesInfoNodeThreadPoolSection + Warmer *NodesInfoNodeThreadPoolSection + type NodesInfoNodeThreadPoolSection struct + KeepAlive string + Max int + Min int + QueueSize interface{} + Type string + type NodesInfoNodeTransport struct + BoundAddress []string + Profiles map[string]*NodesInfoNodeTransportProfile + PublishAddress string + type NodesInfoNodeTransportProfile struct + BoundAddress []string + PublishAddress string + type NodesInfoResponse struct + ClusterName string + Nodes map[string]*NodesInfoNode + type NodesInfoService struct + func NewNodesInfoService(client *Client) *NodesInfoService + func (s *NodesInfoService) Do(ctx context.Context) (*NodesInfoResponse, error) + func (s *NodesInfoService) FlatSettings(flatSettings bool) *NodesInfoService + func (s *NodesInfoService) Human(human bool) *NodesInfoService + func (s *NodesInfoService) Metric(metric ...string) *NodesInfoService + func (s *NodesInfoService) NodeId(nodeId ...string) *NodesInfoService + func (s *NodesInfoService) Pretty(pretty bool) *NodesInfoService + func (s *NodesInfoService) Validate() error + type NodesStatsBreaker struct + EstimatedSize string + EstimatedSizeInBytes int64 + LimitSize string + LimitSizeInBytes int64 + Overhead float64 + Tripped int64 + type NodesStatsCompletionStats struct + Fields map[string]struct{ ... } + Size string + SizeInBytes int64 + type NodesStatsDiscovery struct + ClusterStateQueue *NodesStatsDiscoveryStats + type NodesStatsDiscoveryStats struct + Committed int64 + Pending int64 + Total int64 + type NodesStatsDocsStats struct + Count int64 + Deleted int64 + type NodesStatsFielddataStats struct + Evictions int64 + Fields map[string]struct{ ... } + MemorySize string + MemorySizeInBytes int64 + type NodesStatsFlushStats struct + Total int64 + TotalTime string + TotalTimeInMillis int64 + type NodesStatsGetStats struct + Current int64 + Exists int64 + ExistsTime string + ExistsTimeInMillis int64 + Missing int64 + MissingTime string + MissingTimeInMillis int64 + Time string + TimeInMillis int64 + Total int64 + type NodesStatsIndex struct + Completion *NodesStatsCompletionStats + Docs *NodesStatsDocsStats + Fielddata *NodesStatsFielddataStats + Flush *NodesStatsFlushStats + Get *NodesStatsGetStats + Indexing *NodesStatsIndexingStats + Indices map[string]*NodesStatsIndex + Merges *NodesStatsMergeStats + Percolate *NodesStatsPercolateStats + QueryCache *NodesStatsQueryCacheStats + Recovery NodesStatsRecoveryStats + Refresh *NodesStatsRefreshStats + RequestCache *NodesStatsRequestCacheStats + Search *NodesStatsSearchStats + Segments *NodesStatsSegmentsStats + Shards map[string]*NodesStatsIndex + Store *NodesStatsStoreStats + Suggest *NodesStatsSuggestStats + Translog *NodesStatsTranslogStats + Warmer *NodesStatsWarmerStats + type NodesStatsIndexingStats struct + DeleteCurrent int64 + DeleteTime string + DeleteTimeInMillis int64 + DeleteTotal int64 + IndexCurrent int64 + IndexFailed int64 + IndexTime string + IndexTimeInMillis int64 + IndexTotal int64 + NoopUpdateTotal int64 + Types map[string]*NodesStatsIndexingStats + type NodesStatsIngest struct + Pipelines interface{} + Total *NodesStatsIngestStats + type NodesStatsIngestStats struct + Count int64 + Current int64 + Failed int64 + Time string + TimeInMillis int64 + type NodesStatsMergeStats struct + Current int64 + CurrentDocs int64 + CurrentSize string + CurrentSizeInBytes int64 + Total int64 + TotalDocs int64 + TotalSize string + TotalSizeInBytes int64 + TotalStoppedTime string + TotalStoppedTimeInMillis int64 + TotalThrottleBytes string + TotalThrottleBytesInBytes int64 + TotalThrottledTime string + TotalThrottledTimeInMillis int64 + TotalTime string + TotalTimeInMillis int64 + type NodesStatsNode struct + Attributes map[string]interface{} + Breaker map[string]*NodesStatsBreaker + Discovery *NodesStatsDiscovery + FS *NodesStatsNodeFS + HTTP *NodesStatsNodeHTTP + Host string + IP string + Indices *NodesStatsIndex + Ingest *NodesStatsIngest + JVM *NodesStatsNodeJVM + Name string + OS *NodesStatsNodeOS + Process *NodesStatsNodeProcess + Roles []string + ScriptStats *NodesStatsScriptStats + ThreadPool map[string]*NodesStatsNodeThreadPool + Timestamp int64 + Transport *NodesStatsNodeTransport + TransportAddress string + type NodesStatsNodeFS struct + Data []*NodesStatsNodeFSEntry + IOStats *NodesStatsNodeFSIOStats + Timestamp int64 + Total *NodesStatsNodeFSEntry + type NodesStatsNodeFSEntry struct + Available string + AvailableInBytes int64 + Free string + FreeInBytes int64 + Mount string + Path string + Spins string + Total string + TotalInBytes int64 + Type string + type NodesStatsNodeFSIOStats struct + Devices []*NodesStatsNodeFSIOStatsEntry + Total *NodesStatsNodeFSIOStatsEntry + type NodesStatsNodeFSIOStatsEntry struct + DeviceName string + Operations int64 + ReadKilobytes int64 + ReadOperations int64 + WriteKilobytes int64 + WriteOperations int64 + type NodesStatsNodeHTTP struct + CurrentOpen int + TotalOpened int + type NodesStatsNodeJVM struct + BufferPools map[string]*NodesStatsNodeJVMBufferPool + Classes *NodesStatsNodeJVMClasses + GC *NodesStatsNodeJVMGC + Mem *NodesStatsNodeJVMMem + Threads *NodesStatsNodeJVMThreads + Timestamp int64 + Uptime string + UptimeInMillis int64 + type NodesStatsNodeJVMBufferPool struct + Count int64 + TotalCapacity string + TotalCapacityInBytes int64 + type NodesStatsNodeJVMClasses struct + CurrentLoadedCount int64 + TotalLoadedCount int64 + TotalUnloadedCount int64 + type NodesStatsNodeJVMGC struct + Collectors map[string]*NodesStatsNodeJVMGCCollector + type NodesStatsNodeJVMGCCollector struct + CollectionCount int64 + CollectionTime string + CollectionTimeInMillis int64 + type NodesStatsNodeJVMMem struct + HeapCommitted string + HeapCommittedInBytes int64 + HeapMax string + HeapMaxInBytes int64 + HeapUsed string + HeapUsedInBytes int64 + HeapUsedPercent int + NonHeapCommitted string + NonHeapCommittedInBytes int64 + NonHeapUsed string + NonHeapUsedInBytes int64 + Pools map[string]struct{ ... } + type NodesStatsNodeJVMThreads struct + Count int64 + PeakCount int64 + type NodesStatsNodeOS struct + CPU *NodesStatsNodeOSCPU + Mem *NodesStatsNodeOSMem + Swap *NodesStatsNodeOSSwap + Timestamp int64 + type NodesStatsNodeOSCPU struct + LoadAverage map[string]float64 + Percent int + type NodesStatsNodeOSMem struct + Free string + FreeInBytes int64 + FreePercent int + Total string + TotalInBytes int64 + Used string + UsedInBytes int64 + UsedPercent int + type NodesStatsNodeOSSwap struct + Free string + FreeInBytes int64 + Total string + TotalInBytes int64 + Used string + UsedInBytes int64 + type NodesStatsNodeProcess struct + CPU struct{ ... } + MaxFileDescriptors int64 + Mem struct{ ... } + OpenFileDescriptors int64 + Timestamp int64 + type NodesStatsNodeThreadPool struct + Active int + Completed int64 + Largest int + Queue int + Rejected int64 + Threads int + type NodesStatsNodeTransport struct + RxCount int64 + RxSize string + RxSizeInBytes int64 + ServerOpen int + TxCount int64 + TxSize string + TxSizeInBytes int64 + type NodesStatsPercolateStats struct + Current int64 + MemorySize string + MemorySizeInBytes int64 + Queries int64 + Time string + TimeInMillis int64 + Total int64 + type NodesStatsQueryCacheStats struct + CacheCount int64 + CacheSize int64 + Evictions int64 + HitCount int64 + MemorySize string + MemorySizeInBytes int64 + MissCount int64 + TotalCount int64 + type NodesStatsRecoveryStats struct + CurrentAsSource int + CurrentAsTarget int + type NodesStatsRefreshStats struct + Total int64 + TotalTime string + TotalTimeInMillis int64 + type NodesStatsRequestCacheStats struct + Evictions int64 + HitCount int64 + MemorySize string + MemorySizeInBytes int64 + MissCount int64 + type NodesStatsResponse struct + ClusterName string + Nodes map[string]*NodesStatsNode + type NodesStatsScriptStats struct + CacheEvictions int64 + Compilations int64 + type NodesStatsSearchStats struct + FetchCurrent int64 + FetchTime string + FetchTimeInMillis int64 + FetchTotal int64 + Groups map[string]*NodesStatsSearchStats + OpenContexts int64 + QueryCurrent int64 + QueryTime string + QueryTimeInMillis int64 + QueryTotal int64 + ScrollCurrent int64 + ScrollTime string + ScrollTimeInMillis int64 + ScrollTotal int64 + type NodesStatsSegmentsStats struct + Count int64 + DocValuesMemory string + DocValuesMemoryInBytes int64 + FixedBitSetMemory string + FixedBitSetMemoryInBytes int64 + IndexWriterMaxMemory string + IndexWriterMaxMemoryInBytes int64 + IndexWriterMemory string + IndexWriterMemoryInBytes int64 + Memory string + MemoryInBytes int64 + NormsMemory string + NormsMemoryInBytes int64 + StoredFieldsMemory string + StoredFieldsMemoryInBytes int64 + TermVectorsMemory string + TermVectorsMemoryInBytes int64 + TermsMemory string + TermsMemoryInBytes int64 + VersionMapMemory string + VersionMapMemoryInBytes int64 + type NodesStatsService struct + func NewNodesStatsService(client *Client) *NodesStatsService + func (s *NodesStatsService) CompletionFields(completionFields ...string) *NodesStatsService + func (s *NodesStatsService) Do(ctx context.Context) (*NodesStatsResponse, error) + func (s *NodesStatsService) FielddataFields(fielddataFields ...string) *NodesStatsService + func (s *NodesStatsService) Fields(fields ...string) *NodesStatsService + func (s *NodesStatsService) Groups(groups bool) *NodesStatsService + func (s *NodesStatsService) Human(human bool) *NodesStatsService + func (s *NodesStatsService) IndexMetric(indexMetric ...string) *NodesStatsService + func (s *NodesStatsService) Level(level string) *NodesStatsService + func (s *NodesStatsService) Metric(metric ...string) *NodesStatsService + func (s *NodesStatsService) NodeId(nodeId ...string) *NodesStatsService + func (s *NodesStatsService) Pretty(pretty bool) *NodesStatsService + func (s *NodesStatsService) Timeout(timeout string) *NodesStatsService + func (s *NodesStatsService) Types(types ...string) *NodesStatsService + func (s *NodesStatsService) Validate() error + type NodesStatsStoreStats struct + Size string + SizeInBytes int64 + type NodesStatsSuggestStats struct + Current int64 + Total int64 + TotalTime string + TotalTimeInMillis int64 + type NodesStatsTranslogStats struct + Operations int64 + Size string + SizeInBytes int64 + type NodesStatsWarmerStats struct + Current int64 + Total int64 + TotalTime string + TotalTimeInMillis int64 + type Notify func(error) + type NullContextLogger struct + func (l *NullContextLogger) Printf(ctx context.Context, fmt string, args ...interface{}) + type Operation func() error + type ParentIdQuery struct + func NewParentIdQuery(typ, id string) *ParentIdQuery + func (q *ParentIdQuery) Boost(boost float64) *ParentIdQuery + func (q *ParentIdQuery) Id(id string) *ParentIdQuery + func (q *ParentIdQuery) IgnoreUnmapped(ignore bool) *ParentIdQuery + func (q *ParentIdQuery) InnerHit(innerHit *InnerHit) *ParentIdQuery + func (q *ParentIdQuery) QueryName(queryName string) *ParentIdQuery + func (q *ParentIdQuery) Source() (interface{}, error) + func (q *ParentIdQuery) Type(typ string) *ParentIdQuery + type PercentageScoreSignificanceHeuristic struct + func NewPercentageScoreSignificanceHeuristic() *PercentageScoreSignificanceHeuristic + func (sh *PercentageScoreSignificanceHeuristic) Name() string + func (sh *PercentageScoreSignificanceHeuristic) Source() (interface{}, error) + type PercentileRanksAggregation struct + func NewPercentileRanksAggregation() *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Compression(compression float64) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Estimator(estimator string) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Field(field string) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Format(format string) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Meta(metaData map[string]interface{}) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Script(script *Script) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Source() (interface{}, error) + func (a *PercentileRanksAggregation) SubAggregation(name string, subAggregation Aggregation) *PercentileRanksAggregation + func (a *PercentileRanksAggregation) Values(values ...float64) *PercentileRanksAggregation + type PercentilesAggregation struct + func NewPercentilesAggregation() *PercentilesAggregation + func (a *PercentilesAggregation) Compression(compression float64) *PercentilesAggregation + func (a *PercentilesAggregation) Estimator(estimator string) *PercentilesAggregation + func (a *PercentilesAggregation) Field(field string) *PercentilesAggregation + func (a *PercentilesAggregation) Format(format string) *PercentilesAggregation + func (a *PercentilesAggregation) Meta(metaData map[string]interface{}) *PercentilesAggregation + func (a *PercentilesAggregation) Percentiles(percentiles ...float64) *PercentilesAggregation + func (a *PercentilesAggregation) Script(script *Script) *PercentilesAggregation + func (a *PercentilesAggregation) Source() (interface{}, error) + func (a *PercentilesAggregation) SubAggregation(name string, subAggregation Aggregation) *PercentilesAggregation + type PercentilesBucketAggregation struct + func NewPercentilesBucketAggregation() *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) BucketsPath(bucketsPaths ...string) *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) Format(format string) *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) GapInsertZeros() *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) GapPolicy(gapPolicy string) *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) GapSkip() *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) Meta(metaData map[string]interface{}) *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) Percents(percents ...float64) *PercentilesBucketAggregation + func (p *PercentilesBucketAggregation) Source() (interface{}, error) + type PercolatorQuery struct + func NewPercolatorQuery() *PercolatorQuery + func (q *PercolatorQuery) Document(doc interface{}) *PercolatorQuery + func (q *PercolatorQuery) DocumentType(typ string) *PercolatorQuery + func (q *PercolatorQuery) Field(field string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentId(id string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentIndex(index string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentPreference(preference string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentRouting(routing string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentType(typ string) *PercolatorQuery + func (q *PercolatorQuery) IndexedDocumentVersion(version int64) *PercolatorQuery + func (q *PercolatorQuery) Source() (interface{}, error) + type PerformRequestOptions struct + Body interface{} + ContentType string + IgnoreErrors []int + Method string + Params url.Values + Path string + Retrier Retrier + type PhraseSuggester struct + func NewPhraseSuggester(name string) *PhraseSuggester + func (q *PhraseSuggester) Analyzer(analyzer string) *PhraseSuggester + func (q *PhraseSuggester) CandidateGenerator(generator CandidateGenerator) *PhraseSuggester + func (q *PhraseSuggester) CandidateGenerators(generators ...CandidateGenerator) *PhraseSuggester + func (q *PhraseSuggester) ClearCandidateGenerator() *PhraseSuggester + func (q *PhraseSuggester) CollateParams(collateParams map[string]interface{}) *PhraseSuggester + func (q *PhraseSuggester) CollatePreference(collatePreference string) *PhraseSuggester + func (q *PhraseSuggester) CollatePrune(collatePrune bool) *PhraseSuggester + func (q *PhraseSuggester) CollateQuery(collateQuery string) *PhraseSuggester + func (q *PhraseSuggester) Confidence(confidence float64) *PhraseSuggester + func (q *PhraseSuggester) ContextQueries(queries ...SuggesterContextQuery) *PhraseSuggester + func (q *PhraseSuggester) ContextQuery(query SuggesterContextQuery) *PhraseSuggester + func (q *PhraseSuggester) Field(field string) *PhraseSuggester + func (q *PhraseSuggester) ForceUnigrams(forceUnigrams bool) *PhraseSuggester + func (q *PhraseSuggester) GramSize(gramSize int) *PhraseSuggester + func (q *PhraseSuggester) Highlight(preTag, postTag string) *PhraseSuggester + func (q *PhraseSuggester) MaxErrors(maxErrors float64) *PhraseSuggester + func (q *PhraseSuggester) Name() string + func (q *PhraseSuggester) RealWordErrorLikelihood(realWordErrorLikelihood float64) *PhraseSuggester + func (q *PhraseSuggester) Separator(separator string) *PhraseSuggester + func (q *PhraseSuggester) ShardSize(shardSize int) *PhraseSuggester + func (q *PhraseSuggester) Size(size int) *PhraseSuggester + func (q *PhraseSuggester) SmoothingModel(smoothingModel SmoothingModel) *PhraseSuggester + func (q *PhraseSuggester) Source(includeName bool) (interface{}, error) + func (q *PhraseSuggester) Text(text string) *PhraseSuggester + func (q *PhraseSuggester) TokenLimit(tokenLimit int) *PhraseSuggester + type PingResult struct + ClusterName string + Name string + TagLine string + Version struct{ ... } + type PingService struct + func NewPingService(client *Client) *PingService + func (s *PingService) Do(ctx context.Context) (*PingResult, int, error) + func (s *PingService) HttpHeadOnly(httpHeadOnly bool) *PingService + func (s *PingService) Pretty(pretty bool) *PingService + func (s *PingService) Timeout(timeout string) *PingService + func (s *PingService) URL(url string) *PingService + type PrefixQuery struct + func NewPrefixQuery(name string, prefix string) *PrefixQuery + func (q *PrefixQuery) Boost(boost float64) *PrefixQuery + func (q *PrefixQuery) QueryName(queryName string) *PrefixQuery + func (q *PrefixQuery) Rewrite(rewrite string) *PrefixQuery + func (q *PrefixQuery) Source() (interface{}, error) + type ProfileResult struct + Breakdown map[string]int64 + Children []ProfileResult + Description string + NodeTime string + NodeTimeNanos int64 + Type string + type PutMappingResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type Query interface + Source func() (interface{}, error) + type QueryProfileShardResult struct + Collector []interface{} + Query []ProfileResult + RewriteTime int64 + type QueryRescorer struct + func NewQueryRescorer(query Query) *QueryRescorer + func (r *QueryRescorer) Name() string + func (r *QueryRescorer) QueryWeight(queryWeight float64) *QueryRescorer + func (r *QueryRescorer) RescoreQueryWeight(rescoreQueryWeight float64) *QueryRescorer + func (r *QueryRescorer) ScoreMode(scoreMode string) *QueryRescorer + func (r *QueryRescorer) Source() (interface{}, error) + type QueryStringQuery struct + func NewQueryStringQuery(queryString string) *QueryStringQuery + func (q *QueryStringQuery) AllowLeadingWildcard(allowLeadingWildcard bool) *QueryStringQuery + func (q *QueryStringQuery) AnalyzeWildcard(analyzeWildcard bool) *QueryStringQuery + func (q *QueryStringQuery) Analyzer(analyzer string) *QueryStringQuery + func (q *QueryStringQuery) Boost(boost float64) *QueryStringQuery + func (q *QueryStringQuery) DefaultField(defaultField string) *QueryStringQuery + func (q *QueryStringQuery) DefaultOperator(operator string) *QueryStringQuery + func (q *QueryStringQuery) EnablePositionIncrements(enablePositionIncrements bool) *QueryStringQuery + func (q *QueryStringQuery) Escape(escape bool) *QueryStringQuery + func (q *QueryStringQuery) Field(field string) *QueryStringQuery + func (q *QueryStringQuery) FieldWithBoost(field string, boost float64) *QueryStringQuery + func (q *QueryStringQuery) Fuzziness(fuzziness string) *QueryStringQuery + func (q *QueryStringQuery) FuzzyMaxExpansions(fuzzyMaxExpansions int) *QueryStringQuery + func (q *QueryStringQuery) FuzzyPrefixLength(fuzzyPrefixLength int) *QueryStringQuery + func (q *QueryStringQuery) FuzzyRewrite(fuzzyRewrite string) *QueryStringQuery + func (q *QueryStringQuery) Lenient(lenient bool) *QueryStringQuery + func (q *QueryStringQuery) Locale(locale string) *QueryStringQuery + func (q *QueryStringQuery) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *QueryStringQuery + func (q *QueryStringQuery) MaxDeterminizedState(maxDeterminizedStates int) *QueryStringQuery + func (q *QueryStringQuery) MinimumShouldMatch(minimumShouldMatch string) *QueryStringQuery + func (q *QueryStringQuery) PhraseSlop(phraseSlop int) *QueryStringQuery + func (q *QueryStringQuery) QueryName(queryName string) *QueryStringQuery + func (q *QueryStringQuery) QuoteAnalyzer(quoteAnalyzer string) *QueryStringQuery + func (q *QueryStringQuery) QuoteFieldSuffix(quoteFieldSuffix string) *QueryStringQuery + func (q *QueryStringQuery) Rewrite(rewrite string) *QueryStringQuery + func (q *QueryStringQuery) Source() (interface{}, error) + func (q *QueryStringQuery) TieBreaker(tieBreaker float64) *QueryStringQuery + func (q *QueryStringQuery) TimeZone(timeZone string) *QueryStringQuery + func (q *QueryStringQuery) Type(typ string) *QueryStringQuery + type RandomFunction struct + func NewRandomFunction() *RandomFunction + func (fn *RandomFunction) Field(field string) *RandomFunction + func (fn *RandomFunction) GetWeight() *float64 + func (fn *RandomFunction) Name() string + func (fn *RandomFunction) Seed(seed interface{}) *RandomFunction + func (fn *RandomFunction) Source() (interface{}, error) + func (fn *RandomFunction) Weight(weight float64) *RandomFunction + type RangeAggregation struct + func NewRangeAggregation() *RangeAggregation + func (a *RangeAggregation) AddRange(from, to interface{}) *RangeAggregation + func (a *RangeAggregation) AddRangeWithKey(key string, from, to interface{}) *RangeAggregation + func (a *RangeAggregation) AddUnboundedFrom(to interface{}) *RangeAggregation + func (a *RangeAggregation) AddUnboundedFromWithKey(key string, to interface{}) *RangeAggregation + func (a *RangeAggregation) AddUnboundedTo(from interface{}) *RangeAggregation + func (a *RangeAggregation) AddUnboundedToWithKey(key string, from interface{}) *RangeAggregation + func (a *RangeAggregation) Between(from, to interface{}) *RangeAggregation + func (a *RangeAggregation) BetweenWithKey(key string, from, to interface{}) *RangeAggregation + func (a *RangeAggregation) Field(field string) *RangeAggregation + func (a *RangeAggregation) Gt(from interface{}) *RangeAggregation + func (a *RangeAggregation) GtWithKey(key string, from interface{}) *RangeAggregation + func (a *RangeAggregation) Keyed(keyed bool) *RangeAggregation + func (a *RangeAggregation) Lt(to interface{}) *RangeAggregation + func (a *RangeAggregation) LtWithKey(key string, to interface{}) *RangeAggregation + func (a *RangeAggregation) Meta(metaData map[string]interface{}) *RangeAggregation + func (a *RangeAggregation) Missing(missing interface{}) *RangeAggregation + func (a *RangeAggregation) Script(script *Script) *RangeAggregation + func (a *RangeAggregation) Source() (interface{}, error) + func (a *RangeAggregation) SubAggregation(name string, subAggregation Aggregation) *RangeAggregation + func (a *RangeAggregation) Unmapped(unmapped bool) *RangeAggregation + type RangeQuery struct + func NewRangeQuery(name string) *RangeQuery + func (q *RangeQuery) Boost(boost float64) *RangeQuery + func (q *RangeQuery) Format(format string) *RangeQuery + func (q *RangeQuery) From(from interface{}) *RangeQuery + func (q *RangeQuery) Gt(from interface{}) *RangeQuery + func (q *RangeQuery) Gte(from interface{}) *RangeQuery + func (q *RangeQuery) IncludeLower(includeLower bool) *RangeQuery + func (q *RangeQuery) IncludeUpper(includeUpper bool) *RangeQuery + func (q *RangeQuery) Lt(to interface{}) *RangeQuery + func (q *RangeQuery) Lte(to interface{}) *RangeQuery + func (q *RangeQuery) QueryName(queryName string) *RangeQuery + func (q *RangeQuery) Relation(relation string) *RangeQuery + func (q *RangeQuery) Source() (interface{}, error) + func (q *RangeQuery) TimeZone(timeZone string) *RangeQuery + func (q *RangeQuery) To(to interface{}) *RangeQuery + type RawStringQuery string + func NewRawStringQuery(q string) RawStringQuery + func (q RawStringQuery) Source() (interface{}, error) + type RefreshResult struct + Shards shardsInfo + type RefreshService struct + func NewRefreshService(client *Client) *RefreshService + func (s *RefreshService) Do(ctx context.Context) (*RefreshResult, error) + func (s *RefreshService) Index(index ...string) *RefreshService + func (s *RefreshService) Pretty(pretty bool) *RefreshService + type RegexCompletionSuggesterOptions struct + func NewRegexCompletionSuggesterOptions() *RegexCompletionSuggesterOptions + func (o *RegexCompletionSuggesterOptions) Flags(flags interface{}) *RegexCompletionSuggesterOptions + func (o *RegexCompletionSuggesterOptions) MaxDeterminizedStates(max int) *RegexCompletionSuggesterOptions + func (o *RegexCompletionSuggesterOptions) Source() (interface{}, error) + type RegexpQuery struct + func NewRegexpQuery(name string, regexp string) *RegexpQuery + func (q *RegexpQuery) Boost(boost float64) *RegexpQuery + func (q *RegexpQuery) Flags(flags string) *RegexpQuery + func (q *RegexpQuery) MaxDeterminizedStates(maxDeterminizedStates int) *RegexpQuery + func (q *RegexpQuery) QueryName(queryName string) *RegexpQuery + func (q *RegexpQuery) Rewrite(rewrite string) *RegexpQuery + func (q *RegexpQuery) Source() (interface{}, error) + type ReindexDestination struct + func NewReindexDestination() *ReindexDestination + func (r *ReindexDestination) Discard() *ReindexDestination + func (r *ReindexDestination) Index(index string) *ReindexDestination + func (r *ReindexDestination) Keep() *ReindexDestination + func (r *ReindexDestination) OpType(opType string) *ReindexDestination + func (r *ReindexDestination) Parent(parent string) *ReindexDestination + func (r *ReindexDestination) Routing(routing string) *ReindexDestination + func (r *ReindexDestination) Source() (interface{}, error) + func (r *ReindexDestination) Type(typ string) *ReindexDestination + func (r *ReindexDestination) Version(version int64) *ReindexDestination + func (r *ReindexDestination) VersionType(versionType string) *ReindexDestination + type ReindexRemoteInfo struct + func NewReindexRemoteInfo() *ReindexRemoteInfo + func (ri *ReindexRemoteInfo) ConnectTimeout(timeout string) *ReindexRemoteInfo + func (ri *ReindexRemoteInfo) Host(host string) *ReindexRemoteInfo + func (ri *ReindexRemoteInfo) Password(password string) *ReindexRemoteInfo + func (ri *ReindexRemoteInfo) SocketTimeout(timeout string) *ReindexRemoteInfo + func (ri *ReindexRemoteInfo) Source() (interface{}, error) + func (ri *ReindexRemoteInfo) Username(username string) *ReindexRemoteInfo + type ReindexService struct + func NewReindexService(client *Client) *ReindexService + func (s *ReindexService) AbortOnVersionConflict() *ReindexService + func (s *ReindexService) Body(body interface{}) *ReindexService + func (s *ReindexService) Conflicts(conflicts string) *ReindexService + func (s *ReindexService) Destination(destination *ReindexDestination) *ReindexService + func (s *ReindexService) DestinationIndex(index string) *ReindexService + func (s *ReindexService) DestinationIndexAndType(index, typ string) *ReindexService + func (s *ReindexService) Do(ctx context.Context) (*BulkIndexByScrollResponse, error) + func (s *ReindexService) DoAsync(ctx context.Context) (*StartTaskResult, error) + func (s *ReindexService) Pretty(pretty bool) *ReindexService + func (s *ReindexService) ProceedOnVersionConflict() *ReindexService + func (s *ReindexService) Refresh(refresh string) *ReindexService + func (s *ReindexService) RequestsPerSecond(requestsPerSecond int) *ReindexService + func (s *ReindexService) Script(script *Script) *ReindexService + func (s *ReindexService) Size(size int) *ReindexService + func (s *ReindexService) Slices(slices int) *ReindexService + func (s *ReindexService) Source(source *ReindexSource) *ReindexService + func (s *ReindexService) SourceIndex(index string) *ReindexService + func (s *ReindexService) Timeout(timeout string) *ReindexService + func (s *ReindexService) Validate() error + func (s *ReindexService) WaitForActiveShards(waitForActiveShards string) *ReindexService + func (s *ReindexService) WaitForCompletion(waitForCompletion bool) *ReindexService + type ReindexSource struct + func NewReindexSource() *ReindexSource + func (r *ReindexSource) Index(indices ...string) *ReindexSource + func (r *ReindexSource) Preference(preference string) *ReindexSource + func (r *ReindexSource) Query(query Query) *ReindexSource + func (r *ReindexSource) RemoteInfo(ri *ReindexRemoteInfo) *ReindexSource + func (r *ReindexSource) RequestCache(requestCache bool) *ReindexSource + func (r *ReindexSource) Scroll(scroll string) *ReindexSource + func (r *ReindexSource) SearchType(searchType string) *ReindexSource + func (r *ReindexSource) SearchTypeDfsQueryThenFetch() *ReindexSource + func (r *ReindexSource) SearchTypeQueryThenFetch() *ReindexSource + func (r *ReindexSource) Sort(field string, ascending bool) *ReindexSource + func (r *ReindexSource) SortBy(sorter ...Sorter) *ReindexSource + func (r *ReindexSource) SortWithInfo(info SortInfo) *ReindexSource + func (r *ReindexSource) Source() (interface{}, error) + func (r *ReindexSource) Type(types ...string) *ReindexSource + type Request http.Request + func NewRequest(method, url string) (*Request, error) + func (r *Request) SetBasicAuth(username, password string) + func (r *Request) SetBody(body interface{}, gzipCompress bool) error + type RequestProcessor interface + Process func(ctx context.Context, req *Request) + type Rescore struct + func NewRescore() *Rescore + func (r *Rescore) IsEmpty() bool + func (r *Rescore) Rescorer(rescorer Rescorer) *Rescore + func (r *Rescore) Source() (interface{}, error) + func (r *Rescore) WindowSize(windowSize int) *Rescore + type Rescorer interface + Name func() string + Source func() (interface{}, error) + type Response struct + Body json.RawMessage + Header http.Header + StatusCode int + type RestoreSource struct + Index string + Repository string + Snapshot string + Version string + type Retrier interface + Retry func(ctx context.Context, retry int, req *http.Request, resp *http.Response, ...) (time.Duration, bool, error) + type RetrierFunc func(context.Context, int, *http.Request, *http.Response, error) (time.Duration, bool, error) + type ReverseNestedAggregation struct + func NewReverseNestedAggregation() *ReverseNestedAggregation + func (a *ReverseNestedAggregation) Meta(metaData map[string]interface{}) *ReverseNestedAggregation + func (a *ReverseNestedAggregation) Path(path string) *ReverseNestedAggregation + func (a *ReverseNestedAggregation) Source() (interface{}, error) + func (a *ReverseNestedAggregation) SubAggregation(name string, subAggregation Aggregation) *ReverseNestedAggregation + type SamplerAggregation struct + func NewSamplerAggregation() *SamplerAggregation + func (a *SamplerAggregation) ExecutionHint(hint string) *SamplerAggregation + func (a *SamplerAggregation) MaxDocsPerValue(maxDocsPerValue int) *SamplerAggregation + func (a *SamplerAggregation) Meta(metaData map[string]interface{}) *SamplerAggregation + func (a *SamplerAggregation) ShardSize(shardSize int) *SamplerAggregation + func (a *SamplerAggregation) Source() (interface{}, error) + func (a *SamplerAggregation) SubAggregation(name string, subAggregation Aggregation) *SamplerAggregation + type ScoreFunction interface + GetWeight func() *float64 + Name func() string + Source func() (interface{}, error) + type ScoreSort struct + func NewScoreSort() *ScoreSort + func (s *ScoreSort) Asc() *ScoreSort + func (s *ScoreSort) Desc() *ScoreSort + func (s *ScoreSort) Order(ascending bool) *ScoreSort + func (s *ScoreSort) Source() (interface{}, error) + type Script struct + func NewScript(script string) *Script + func NewScriptInline(script string) *Script + func NewScriptStored(script string) *Script + func (s *Script) Lang(lang string) *Script + func (s *Script) Param(name string, value interface{}) *Script + func (s *Script) Params(params map[string]interface{}) *Script + func (s *Script) Script(script string) *Script + func (s *Script) Source() (interface{}, error) + func (s *Script) Type(typ string) *Script + type ScriptField struct + FieldName string + func NewScriptField(fieldName string, script *Script) *ScriptField + func (f *ScriptField) Source() (interface{}, error) + type ScriptFunction struct + func NewScriptFunction(script *Script) *ScriptFunction + func (fn *ScriptFunction) GetWeight() *float64 + func (fn *ScriptFunction) Name() string + func (fn *ScriptFunction) Script(script *Script) *ScriptFunction + func (fn *ScriptFunction) Source() (interface{}, error) + func (fn *ScriptFunction) Weight(weight float64) *ScriptFunction + type ScriptQuery struct + func NewScriptQuery(script *Script) *ScriptQuery + func (q *ScriptQuery) QueryName(queryName string) *ScriptQuery + func (q *ScriptQuery) Source() (interface{}, error) + type ScriptSignificanceHeuristic struct + func NewScriptSignificanceHeuristic() *ScriptSignificanceHeuristic + func (sh *ScriptSignificanceHeuristic) Name() string + func (sh *ScriptSignificanceHeuristic) Script(script *Script) *ScriptSignificanceHeuristic + func (sh *ScriptSignificanceHeuristic) Source() (interface{}, error) + type ScriptSort struct + func NewScriptSort(script *Script, typ string) *ScriptSort + func (s *ScriptSort) Asc() *ScriptSort + func (s *ScriptSort) Desc() *ScriptSort + func (s *ScriptSort) NestedFilter(nestedFilter Query) *ScriptSort + func (s *ScriptSort) NestedPath(nestedPath string) *ScriptSort + func (s *ScriptSort) NestedSort(nestedSort *NestedSort) *ScriptSort + func (s *ScriptSort) Order(ascending bool) *ScriptSort + func (s *ScriptSort) SortMode(sortMode string) *ScriptSort + func (s *ScriptSort) Source() (interface{}, error) + func (s *ScriptSort) Type(typ string) *ScriptSort + type ScrollService struct + func NewScrollService(client *Client) *ScrollService + func (s *ScrollService) AllowNoIndices(allowNoIndices bool) *ScrollService + func (s *ScrollService) Body(body interface{}) *ScrollService + func (s *ScrollService) Clear(ctx context.Context) error + func (s *ScrollService) Do(ctx context.Context) (*SearchResult, error) + func (s *ScrollService) ExpandWildcards(expandWildcards string) *ScrollService + func (s *ScrollService) FetchSource(fetchSource bool) *ScrollService + func (s *ScrollService) FetchSourceContext(fetchSourceContext *FetchSourceContext) *ScrollService + func (s *ScrollService) IgnoreUnavailable(ignoreUnavailable bool) *ScrollService + func (s *ScrollService) Index(indices ...string) *ScrollService + func (s *ScrollService) KeepAlive(keepAlive string) *ScrollService + func (s *ScrollService) PostFilter(postFilter Query) *ScrollService + func (s *ScrollService) Preference(preference string) *ScrollService + func (s *ScrollService) Pretty(pretty bool) *ScrollService + func (s *ScrollService) Query(query Query) *ScrollService + func (s *ScrollService) Retrier(retrier Retrier) *ScrollService + func (s *ScrollService) Routing(routings ...string) *ScrollService + func (s *ScrollService) Scroll(keepAlive string) *ScrollService + func (s *ScrollService) ScrollId(scrollId string) *ScrollService + func (s *ScrollService) SearchSource(searchSource *SearchSource) *ScrollService + func (s *ScrollService) Size(size int) *ScrollService + func (s *ScrollService) Slice(sliceQuery Query) *ScrollService + func (s *ScrollService) Sort(field string, ascending bool) *ScrollService + func (s *ScrollService) SortBy(sorter ...Sorter) *ScrollService + func (s *ScrollService) SortWithInfo(info SortInfo) *ScrollService + func (s *ScrollService) Type(types ...string) *ScrollService + func (s *ScrollService) Version(version bool) *ScrollService + type SearchExplanation struct + Description string + Details []SearchExplanation + Value float64 + type SearchHit struct + Explanation *SearchExplanation + Fields map[string]interface{} + Highlight SearchHitHighlight + Id string + Index string + InnerHits map[string]*SearchHitInnerHits + MatchedQueries []string + Nested *NestedHit + Parent string + Routing string + Score *float64 + Sort []interface{} + Source *json.RawMessage + Type string + Uid string + Version *int64 + type SearchHitHighlight map[string][]string + type SearchHitInnerHits struct + Hits *SearchHits + type SearchHits struct + Hits []*SearchHit + MaxScore *float64 + TotalHits int64 + type SearchProfile struct + Shards []SearchProfileShardResult + type SearchProfileShardResult struct + Aggregations []ProfileResult + ID string + Searches []QueryProfileShardResult + type SearchRequest struct + func NewSearchRequest() *SearchRequest + func (r *SearchRequest) Body() (string, error) + func (r *SearchRequest) HasIndices() bool + func (r *SearchRequest) Index(indices ...string) *SearchRequest + func (r *SearchRequest) Preference(preference string) *SearchRequest + func (r *SearchRequest) RequestCache(requestCache bool) *SearchRequest + func (r *SearchRequest) Routing(routing string) *SearchRequest + func (r *SearchRequest) Routings(routings ...string) *SearchRequest + func (r *SearchRequest) Scroll(scroll string) *SearchRequest + func (r *SearchRequest) SearchSource(searchSource *SearchSource) *SearchRequest + func (r *SearchRequest) SearchType(searchType string) *SearchRequest + func (r *SearchRequest) SearchTypeDfsQueryThenFetch() *SearchRequest + func (r *SearchRequest) SearchTypeQueryThenFetch() *SearchRequest + func (r *SearchRequest) Source(source interface{}) *SearchRequest + func (r *SearchRequest) Type(types ...string) *SearchRequest + func (s *SearchRequest) AllowNoIndices(allowNoIndices bool) *SearchRequest + func (s *SearchRequest) ExpandWildcards(expandWildcards string) *SearchRequest + func (s *SearchRequest) IgnoreUnavailable(ignoreUnavailable bool) *SearchRequest + type SearchResult struct + Aggregations Aggregations + Error *ErrorDetails + Hits *SearchHits + Profile *SearchProfile + ScrollId string + Shards *shardsInfo + Suggest SearchSuggest + TimedOut bool + TookInMillis int64 + func (r *SearchResult) Each(typ reflect.Type) []interface{} + func (r *SearchResult) TotalHits() int64 + type SearchService struct + func NewSearchService(client *Client) *SearchService + func (s *SearchService) Aggregation(name string, aggregation Aggregation) *SearchService + func (s *SearchService) AllowNoIndices(allowNoIndices bool) *SearchService + func (s *SearchService) Collapse(collapse *CollapseBuilder) *SearchService + func (s *SearchService) Do(ctx context.Context) (*SearchResult, error) + func (s *SearchService) ExpandWildcards(expandWildcards string) *SearchService + func (s *SearchService) Explain(explain bool) *SearchService + func (s *SearchService) FetchSource(fetchSource bool) *SearchService + func (s *SearchService) FetchSourceContext(fetchSourceContext *FetchSourceContext) *SearchService + func (s *SearchService) FilterPath(filterPath ...string) *SearchService + func (s *SearchService) From(from int) *SearchService + func (s *SearchService) GlobalSuggestText(globalText string) *SearchService + func (s *SearchService) Highlight(highlight *Highlight) *SearchService + func (s *SearchService) IgnoreUnavailable(ignoreUnavailable bool) *SearchService + func (s *SearchService) Index(index ...string) *SearchService + func (s *SearchService) MinScore(minScore float64) *SearchService + func (s *SearchService) NoStoredFields() *SearchService + func (s *SearchService) PostFilter(postFilter Query) *SearchService + func (s *SearchService) Preference(preference string) *SearchService + func (s *SearchService) Pretty(pretty bool) *SearchService + func (s *SearchService) Profile(profile bool) *SearchService + func (s *SearchService) Query(query Query) *SearchService + func (s *SearchService) RequestCache(requestCache bool) *SearchService + func (s *SearchService) Routing(routings ...string) *SearchService + func (s *SearchService) SearchAfter(sortValues ...interface{}) *SearchService + func (s *SearchService) SearchSource(searchSource *SearchSource) *SearchService + func (s *SearchService) SearchType(searchType string) *SearchService + func (s *SearchService) Size(size int) *SearchService + func (s *SearchService) Sort(field string, ascending bool) *SearchService + func (s *SearchService) SortBy(sorter ...Sorter) *SearchService + func (s *SearchService) SortWithInfo(info SortInfo) *SearchService + func (s *SearchService) Source(source interface{}) *SearchService + func (s *SearchService) StoredField(fieldName string) *SearchService + func (s *SearchService) StoredFields(fields ...string) *SearchService + func (s *SearchService) Suggester(suggester Suggester) *SearchService + func (s *SearchService) TerminateAfter(terminateAfter int) *SearchService + func (s *SearchService) Timeout(timeout string) *SearchService + func (s *SearchService) TimeoutInMillis(timeoutInMillis int) *SearchService + func (s *SearchService) TrackScores(trackScores bool) *SearchService + func (s *SearchService) Type(typ ...string) *SearchService + func (s *SearchService) Validate() error + func (s *SearchService) Version(version bool) *SearchService + type SearchShardsResponse struct + Indices map[string]interface{} + Nodes map[string]interface{} + Shards [][]ShardsInfo + type SearchShardsService struct + func NewSearchShardsService(client *Client) *SearchShardsService + func (s *SearchShardsService) AllowNoIndices(allowNoIndices bool) *SearchShardsService + func (s *SearchShardsService) Do(ctx context.Context) (*SearchShardsResponse, error) + func (s *SearchShardsService) ExpandWildcards(expandWildcards string) *SearchShardsService + func (s *SearchShardsService) IgnoreUnavailable(ignoreUnavailable bool) *SearchShardsService + func (s *SearchShardsService) Index(index ...string) *SearchShardsService + func (s *SearchShardsService) Local(local bool) *SearchShardsService + func (s *SearchShardsService) Preference(preference string) *SearchShardsService + func (s *SearchShardsService) Pretty(pretty bool) *SearchShardsService + func (s *SearchShardsService) Routing(routing string) *SearchShardsService + func (s *SearchShardsService) Validate() error + type SearchSource struct + func NewSearchSource() *SearchSource + func (s *SearchSource) Aggregation(name string, aggregation Aggregation) *SearchSource + func (s *SearchSource) ClearRescorers() *SearchSource + func (s *SearchSource) Collapse(collapse *CollapseBuilder) *SearchSource + func (s *SearchSource) DefaultRescoreWindowSize(defaultRescoreWindowSize int) *SearchSource + func (s *SearchSource) DocvalueField(fieldDataField string) *SearchSource + func (s *SearchSource) DocvalueFields(docvalueFields ...string) *SearchSource + func (s *SearchSource) Explain(explain bool) *SearchSource + func (s *SearchSource) FetchSource(fetchSource bool) *SearchSource + func (s *SearchSource) FetchSourceContext(fetchSourceContext *FetchSourceContext) *SearchSource + func (s *SearchSource) From(from int) *SearchSource + func (s *SearchSource) GlobalSuggestText(text string) *SearchSource + func (s *SearchSource) Highlight(highlight *Highlight) *SearchSource + func (s *SearchSource) Highlighter() *Highlight + func (s *SearchSource) IndexBoost(index string, boost float64) *SearchSource + func (s *SearchSource) InnerHit(name string, innerHit *InnerHit) *SearchSource + func (s *SearchSource) MinScore(minScore float64) *SearchSource + func (s *SearchSource) NoStoredFields() *SearchSource + func (s *SearchSource) PostFilter(postFilter Query) *SearchSource + func (s *SearchSource) Profile(profile bool) *SearchSource + func (s *SearchSource) Query(query Query) *SearchSource + func (s *SearchSource) Rescorer(rescore *Rescore) *SearchSource + func (s *SearchSource) ScriptField(scriptField *ScriptField) *SearchSource + func (s *SearchSource) ScriptFields(scriptFields ...*ScriptField) *SearchSource + func (s *SearchSource) SearchAfter(sortValues ...interface{}) *SearchSource + func (s *SearchSource) Size(size int) *SearchSource + func (s *SearchSource) Slice(sliceQuery Query) *SearchSource + func (s *SearchSource) Sort(field string, ascending bool) *SearchSource + func (s *SearchSource) SortBy(sorter ...Sorter) *SearchSource + func (s *SearchSource) SortWithInfo(info SortInfo) *SearchSource + func (s *SearchSource) Source() (interface{}, error) + func (s *SearchSource) Stats(statsGroup ...string) *SearchSource + func (s *SearchSource) StoredField(storedFieldName string) *SearchSource + func (s *SearchSource) StoredFields(storedFieldNames ...string) *SearchSource + func (s *SearchSource) Suggester(suggester Suggester) *SearchSource + func (s *SearchSource) TerminateAfter(terminateAfter int) *SearchSource + func (s *SearchSource) Timeout(timeout string) *SearchSource + func (s *SearchSource) TimeoutInMillis(timeoutInMillis int) *SearchSource + func (s *SearchSource) TrackScores(trackScores bool) *SearchSource + func (s *SearchSource) TrackTotalHits(trackTotalHits bool) *SearchSource + func (s *SearchSource) Version(version bool) *SearchSource + type SearchSuggest map[string][]SearchSuggestion + type SearchSuggestion struct + Length int + Offset int + Options []SearchSuggestionOption + Text string + type SearchSuggestionOption struct + CollateMatch bool + Freq int + Highlighted string + Id string + Index string + Score float64 + ScoreUnderscore float64 + Source *json.RawMessage + Text string + Type string + type SerialDiffAggregation struct + func NewSerialDiffAggregation() *SerialDiffAggregation + func (a *SerialDiffAggregation) BucketsPath(bucketsPaths ...string) *SerialDiffAggregation + func (a *SerialDiffAggregation) Format(format string) *SerialDiffAggregation + func (a *SerialDiffAggregation) GapInsertZeros() *SerialDiffAggregation + func (a *SerialDiffAggregation) GapPolicy(gapPolicy string) *SerialDiffAggregation + func (a *SerialDiffAggregation) GapSkip() *SerialDiffAggregation + func (a *SerialDiffAggregation) Lag(lag int) *SerialDiffAggregation + func (a *SerialDiffAggregation) Meta(metaData map[string]interface{}) *SerialDiffAggregation + func (a *SerialDiffAggregation) Source() (interface{}, error) + type ShardsInfo struct + AllocationId interface{} + Index string + Node string + Primary bool + RelocatingNode bool + Shard uint + State string + type SignificanceHeuristic interface + Name func() string + Source func() (interface{}, error) + type SignificantTermsAggregation struct + func NewSignificantTermsAggregation() *SignificantTermsAggregation + func (a *SignificantTermsAggregation) BackgroundFilter(filter Query) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) ExecutionHint(hint string) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) Field(field string) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) Meta(metaData map[string]interface{}) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) MinDocCount(minDocCount int) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) RequiredSize(requiredSize int) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) ShardMinDocCount(shardMinDocCount int) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) ShardSize(shardSize int) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) SignificanceHeuristic(heuristic SignificanceHeuristic) *SignificantTermsAggregation + func (a *SignificantTermsAggregation) Source() (interface{}, error) + func (a *SignificantTermsAggregation) SubAggregation(name string, subAggregation Aggregation) *SignificantTermsAggregation + type SignificantTextAggregation struct + func NewSignificantTextAggregation() *SignificantTextAggregation + func (a *SignificantTextAggregation) BackgroundFilter(filter Query) *SignificantTextAggregation + func (a *SignificantTextAggregation) Exclude(regexp string) *SignificantTextAggregation + func (a *SignificantTextAggregation) ExcludeValues(values ...interface{}) *SignificantTextAggregation + func (a *SignificantTextAggregation) Field(field string) *SignificantTextAggregation + func (a *SignificantTextAggregation) FilterDuplicateText(filter bool) *SignificantTextAggregation + func (a *SignificantTextAggregation) Include(regexp string) *SignificantTextAggregation + func (a *SignificantTextAggregation) IncludeValues(values ...interface{}) *SignificantTextAggregation + func (a *SignificantTextAggregation) Meta(metaData map[string]interface{}) *SignificantTextAggregation + func (a *SignificantTextAggregation) MinDocCount(minDocCount int64) *SignificantTextAggregation + func (a *SignificantTextAggregation) NumPartitions(n int) *SignificantTextAggregation + func (a *SignificantTextAggregation) Partition(p int) *SignificantTextAggregation + func (a *SignificantTextAggregation) ShardMinDocCount(shardMinDocCount int64) *SignificantTextAggregation + func (a *SignificantTextAggregation) ShardSize(shardSize int) *SignificantTextAggregation + func (a *SignificantTextAggregation) SignificanceHeuristic(heuristic SignificanceHeuristic) *SignificantTextAggregation + func (a *SignificantTextAggregation) Size(size int) *SignificantTextAggregation + func (a *SignificantTextAggregation) Source() (interface{}, error) + func (a *SignificantTextAggregation) SourceFieldNames(names ...string) *SignificantTextAggregation + func (a *SignificantTextAggregation) SubAggregation(name string, subAggregation Aggregation) *SignificantTextAggregation + type SimpleBackoff struct + func NewSimpleBackoff(ticks ...int) *SimpleBackoff + func (b *SimpleBackoff) Jitter(flag bool) *SimpleBackoff + func (b *SimpleBackoff) Next(retry int) (time.Duration, bool) + type SimpleMovAvgModel struct + func NewSimpleMovAvgModel() *SimpleMovAvgModel + func (m *SimpleMovAvgModel) Name() string + func (m *SimpleMovAvgModel) Settings() map[string]interface{} + type SimpleQueryStringQuery struct + func NewSimpleQueryStringQuery(text string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) AnalyzeWildcard(analyzeWildcard bool) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Analyzer(analyzer string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) AutoGenerateSynonymsPhraseQuery(enable bool) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Boost(boost float64) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) DefaultOperator(defaultOperator string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Field(field string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) FieldWithBoost(field string, boost float64) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Flags(flags string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) FuzzyMaxExpansions(fuzzyMaxExpansions int) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) FuzzyPrefixLength(fuzzyPrefixLength int) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) FuzzyTranspositions(fuzzyTranspositions bool) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Lenient(lenient bool) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Locale(locale string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) MinimumShouldMatch(minimumShouldMatch string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) QueryName(queryName string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) QuoteFieldSuffix(quoteFieldSuffix string) *SimpleQueryStringQuery + func (q *SimpleQueryStringQuery) Source() (interface{}, error) + type SliceQuery struct + func NewSliceQuery() *SliceQuery + func (s *SliceQuery) Field(field string) *SliceQuery + func (s *SliceQuery) Id(id int) *SliceQuery + func (s *SliceQuery) Max(max int) *SliceQuery + func (s *SliceQuery) Source() (interface{}, error) + type SmoothingModel interface + Source func() (interface{}, error) + Type func() string + type SnapshotCreateRepositoryResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type SnapshotCreateRepositoryService struct + func NewSnapshotCreateRepositoryService(client *Client) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) BodyJson(body interface{}) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) BodyString(body string) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Do(ctx context.Context) (*SnapshotCreateRepositoryResponse, error) + func (s *SnapshotCreateRepositoryService) MasterTimeout(masterTimeout string) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Pretty(pretty bool) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Repository(repository string) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Setting(name string, value interface{}) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Settings(settings map[string]interface{}) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Timeout(timeout string) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Type(typ string) *SnapshotCreateRepositoryService + func (s *SnapshotCreateRepositoryService) Validate() error + func (s *SnapshotCreateRepositoryService) Verify(verify bool) *SnapshotCreateRepositoryService + type SnapshotCreateResponse struct + Accepted *bool + Snapshot ... + type SnapshotCreateService struct + func NewSnapshotCreateService(client *Client) *SnapshotCreateService + func (s *SnapshotCreateService) BodyJson(body interface{}) *SnapshotCreateService + func (s *SnapshotCreateService) BodyString(body string) *SnapshotCreateService + func (s *SnapshotCreateService) Do(ctx context.Context) (*SnapshotCreateResponse, error) + func (s *SnapshotCreateService) MasterTimeout(masterTimeout string) *SnapshotCreateService + func (s *SnapshotCreateService) Pretty(pretty bool) *SnapshotCreateService + func (s *SnapshotCreateService) Repository(repository string) *SnapshotCreateService + func (s *SnapshotCreateService) Snapshot(snapshot string) *SnapshotCreateService + func (s *SnapshotCreateService) Validate() error + func (s *SnapshotCreateService) WaitForCompletion(waitForCompletion bool) *SnapshotCreateService + type SnapshotDeleteRepositoryResponse struct + Acknowledged bool + Index string + ShardsAcknowledged bool + type SnapshotDeleteRepositoryService struct + func NewSnapshotDeleteRepositoryService(client *Client) *SnapshotDeleteRepositoryService + func (s *SnapshotDeleteRepositoryService) Do(ctx context.Context) (*SnapshotDeleteRepositoryResponse, error) + func (s *SnapshotDeleteRepositoryService) MasterTimeout(masterTimeout string) *SnapshotDeleteRepositoryService + func (s *SnapshotDeleteRepositoryService) Pretty(pretty bool) *SnapshotDeleteRepositoryService + func (s *SnapshotDeleteRepositoryService) Repository(repositories ...string) *SnapshotDeleteRepositoryService + func (s *SnapshotDeleteRepositoryService) Timeout(timeout string) *SnapshotDeleteRepositoryService + func (s *SnapshotDeleteRepositoryService) Validate() error + type SnapshotGetRepositoryResponse map[string]*SnapshotRepositoryMetaData + type SnapshotGetRepositoryService struct + func NewSnapshotGetRepositoryService(client *Client) *SnapshotGetRepositoryService + func (s *SnapshotGetRepositoryService) Do(ctx context.Context) (SnapshotGetRepositoryResponse, error) + func (s *SnapshotGetRepositoryService) Local(local bool) *SnapshotGetRepositoryService + func (s *SnapshotGetRepositoryService) MasterTimeout(masterTimeout string) *SnapshotGetRepositoryService + func (s *SnapshotGetRepositoryService) Pretty(pretty bool) *SnapshotGetRepositoryService + func (s *SnapshotGetRepositoryService) Repository(repositories ...string) *SnapshotGetRepositoryService + func (s *SnapshotGetRepositoryService) Validate() error + type SnapshotRepositoryMetaData struct + Settings map[string]interface{} + Type string + type SnapshotShardFailure struct + Index string + IndexUUID string + NodeID string + Reason string + ShardID int + Status string + type SnapshotVerifyRepositoryNode struct + Name string + type SnapshotVerifyRepositoryResponse struct + Nodes map[string]*SnapshotVerifyRepositoryNode + type SnapshotVerifyRepositoryService struct + func NewSnapshotVerifyRepositoryService(client *Client) *SnapshotVerifyRepositoryService + func (s *SnapshotVerifyRepositoryService) Do(ctx context.Context) (*SnapshotVerifyRepositoryResponse, error) + func (s *SnapshotVerifyRepositoryService) MasterTimeout(masterTimeout string) *SnapshotVerifyRepositoryService + func (s *SnapshotVerifyRepositoryService) Pretty(pretty bool) *SnapshotVerifyRepositoryService + func (s *SnapshotVerifyRepositoryService) Repository(repository string) *SnapshotVerifyRepositoryService + func (s *SnapshotVerifyRepositoryService) Timeout(timeout string) *SnapshotVerifyRepositoryService + func (s *SnapshotVerifyRepositoryService) Validate() error + type SnifferCallback func(*NodesInfoNode) bool + type SortByDoc struct + func (s SortByDoc) Source() (interface{}, error) + type SortInfo struct + Ascending bool + Field string + IgnoreUnmapped *bool + Missing interface{} + NestedFilter Query + NestedPath string + NestedSort *NestedSort + SortMode string + UnmappedType string + func (info SortInfo) Source() (interface{}, error) + type Sorter interface + Source func() (interface{}, error) + type StartTaskResult struct + TaskId string + type StatsAggregation struct + func NewStatsAggregation() *StatsAggregation + func (a *StatsAggregation) Field(field string) *StatsAggregation + func (a *StatsAggregation) Format(format string) *StatsAggregation + func (a *StatsAggregation) Meta(metaData map[string]interface{}) *StatsAggregation + func (a *StatsAggregation) Script(script *Script) *StatsAggregation + func (a *StatsAggregation) Source() (interface{}, error) + func (a *StatsAggregation) SubAggregation(name string, subAggregation Aggregation) *StatsAggregation + type StatsBucketAggregation struct + func NewStatsBucketAggregation() *StatsBucketAggregation + func (s *StatsBucketAggregation) BucketsPath(bucketsPaths ...string) *StatsBucketAggregation + func (s *StatsBucketAggregation) Format(format string) *StatsBucketAggregation + func (s *StatsBucketAggregation) GapInsertZeros() *StatsBucketAggregation + func (s *StatsBucketAggregation) GapPolicy(gapPolicy string) *StatsBucketAggregation + func (s *StatsBucketAggregation) GapSkip() *StatsBucketAggregation + func (s *StatsBucketAggregation) Meta(metaData map[string]interface{}) *StatsBucketAggregation + func (s *StatsBucketAggregation) Source() (interface{}, error) + type StopBackoff struct + func (b StopBackoff) Next(retry int) (time.Duration, bool) + type StopRetrier struct + func NewStopRetrier() *StopRetrier + func (r *StopRetrier) Retry(ctx context.Context, retry int, req *http.Request, resp *http.Response, ...) (time.Duration, bool, error) + type StupidBackoffSmoothingModel struct + func NewStupidBackoffSmoothingModel(discount float64) *StupidBackoffSmoothingModel + func (sm *StupidBackoffSmoothingModel) Source() (interface{}, error) + func (sm *StupidBackoffSmoothingModel) Type() string + type SuggestField struct + func NewSuggestField(input ...string) *SuggestField + func (f *SuggestField) ContextQuery(queries ...SuggesterContextQuery) *SuggestField + func (f *SuggestField) Input(input ...string) *SuggestField + func (f *SuggestField) MarshalJSON() ([]byte, error) + func (f *SuggestField) Weight(weight int) *SuggestField + type Suggester interface + Name func() string + Source func(includeName bool) (interface{}, error) + type SuggesterCategoryMapping struct + func NewSuggesterCategoryMapping(name string) *SuggesterCategoryMapping + func (q *SuggesterCategoryMapping) DefaultValues(values ...string) *SuggesterCategoryMapping + func (q *SuggesterCategoryMapping) FieldName(fieldName string) *SuggesterCategoryMapping + func (q *SuggesterCategoryMapping) Source() (interface{}, error) + type SuggesterCategoryQuery struct + func NewSuggesterCategoryQuery(name string, values ...string) *SuggesterCategoryQuery + func (q *SuggesterCategoryQuery) Source() (interface{}, error) + func (q *SuggesterCategoryQuery) Value(val string) *SuggesterCategoryQuery + func (q *SuggesterCategoryQuery) ValueWithBoost(val string, boost int) *SuggesterCategoryQuery + func (q *SuggesterCategoryQuery) Values(values ...string) *SuggesterCategoryQuery + type SuggesterContextQuery interface + Source func() (interface{}, error) + type SuggesterGeoMapping struct + func NewSuggesterGeoMapping(name string) *SuggesterGeoMapping + func (q *SuggesterGeoMapping) DefaultLocations(locations ...*GeoPoint) *SuggesterGeoMapping + func (q *SuggesterGeoMapping) FieldName(fieldName string) *SuggesterGeoMapping + func (q *SuggesterGeoMapping) Neighbors(neighbors bool) *SuggesterGeoMapping + func (q *SuggesterGeoMapping) Precision(precision ...string) *SuggesterGeoMapping + func (q *SuggesterGeoMapping) Source() (interface{}, error) + type SuggesterGeoQuery struct + func NewSuggesterGeoQuery(name string, location *GeoPoint) *SuggesterGeoQuery + func (q *SuggesterGeoQuery) Precision(precision ...string) *SuggesterGeoQuery + func (q *SuggesterGeoQuery) Source() (interface{}, error) + type SumAggregation struct + func NewSumAggregation() *SumAggregation + func (a *SumAggregation) Field(field string) *SumAggregation + func (a *SumAggregation) Format(format string) *SumAggregation + func (a *SumAggregation) Meta(metaData map[string]interface{}) *SumAggregation + func (a *SumAggregation) Script(script *Script) *SumAggregation + func (a *SumAggregation) Source() (interface{}, error) + func (a *SumAggregation) SubAggregation(name string, subAggregation Aggregation) *SumAggregation + type SumBucketAggregation struct + func NewSumBucketAggregation() *SumBucketAggregation + func (a *SumBucketAggregation) BucketsPath(bucketsPaths ...string) *SumBucketAggregation + func (a *SumBucketAggregation) Format(format string) *SumBucketAggregation + func (a *SumBucketAggregation) GapInsertZeros() *SumBucketAggregation + func (a *SumBucketAggregation) GapPolicy(gapPolicy string) *SumBucketAggregation + func (a *SumBucketAggregation) GapSkip() *SumBucketAggregation + func (a *SumBucketAggregation) Meta(metaData map[string]interface{}) *SumBucketAggregation + func (a *SumBucketAggregation) Source() (interface{}, error) + type TaskInfo struct + Action string + Cancellable bool + Description interface{} + Id int64 + Node string + ParentTaskId string + RunningTime string + RunningTimeInNanos int64 + StartTime string + StartTimeInMillis int64 + Status interface{} + Type string + type TaskOperationFailure struct + NodeId string + Reason *ErrorDetails + Status string + TaskId int64 + type TasksCancelService struct + func NewTasksCancelService(client *Client) *TasksCancelService + func (s *TasksCancelService) Actions(actions []string) *TasksCancelService + func (s *TasksCancelService) Do(ctx context.Context) (*TasksListResponse, error) + func (s *TasksCancelService) NodeId(nodeId []string) *TasksCancelService + func (s *TasksCancelService) ParentNode(parentNode string) *TasksCancelService + func (s *TasksCancelService) ParentTask(parentTask int64) *TasksCancelService + func (s *TasksCancelService) Pretty(pretty bool) *TasksCancelService + func (s *TasksCancelService) TaskId(taskId int64) *TasksCancelService + func (s *TasksCancelService) Validate() error + type TasksGetTaskResponse struct + Completed bool + Task *TaskInfo + type TasksGetTaskService struct + func NewTasksGetTaskService(client *Client) *TasksGetTaskService + func (s *TasksGetTaskService) Do(ctx context.Context) (*TasksGetTaskResponse, error) + func (s *TasksGetTaskService) Pretty(pretty bool) *TasksGetTaskService + func (s *TasksGetTaskService) TaskId(taskId string) *TasksGetTaskService + func (s *TasksGetTaskService) Validate() error + func (s *TasksGetTaskService) WaitForCompletion(waitForCompletion bool) *TasksGetTaskService + type TasksListResponse struct + NodeFailures []*FailedNodeException + Nodes map[string]*DiscoveryNode + TaskFailures []*TaskOperationFailure + type TasksListService struct + func NewTasksListService(client *Client) *TasksListService + func (s *TasksListService) Actions(actions ...string) *TasksListService + func (s *TasksListService) Detailed(detailed bool) *TasksListService + func (s *TasksListService) Do(ctx context.Context) (*TasksListResponse, error) + func (s *TasksListService) GroupBy(groupBy string) *TasksListService + func (s *TasksListService) Human(human bool) *TasksListService + func (s *TasksListService) NodeId(nodeId ...string) *TasksListService + func (s *TasksListService) ParentNode(parentNode string) *TasksListService + func (s *TasksListService) ParentTaskId(parentTaskId string) *TasksListService + func (s *TasksListService) Pretty(pretty bool) *TasksListService + func (s *TasksListService) TaskId(taskId ...string) *TasksListService + func (s *TasksListService) Validate() error + func (s *TasksListService) WaitForCompletion(waitForCompletion bool) *TasksListService + type TermQuery struct + func NewTermQuery(name string, value interface{}) *TermQuery + func (q *TermQuery) Boost(boost float64) *TermQuery + func (q *TermQuery) QueryName(queryName string) *TermQuery + func (q *TermQuery) Source() (interface{}, error) + type TermSuggester struct + func NewTermSuggester(name string) *TermSuggester + func (q *TermSuggester) Accuracy(accuracy float64) *TermSuggester + func (q *TermSuggester) Analyzer(analyzer string) *TermSuggester + func (q *TermSuggester) ContextQueries(queries ...SuggesterContextQuery) *TermSuggester + func (q *TermSuggester) ContextQuery(query SuggesterContextQuery) *TermSuggester + func (q *TermSuggester) Field(field string) *TermSuggester + func (q *TermSuggester) MaxEdits(maxEdits int) *TermSuggester + func (q *TermSuggester) MaxInspections(maxInspections int) *TermSuggester + func (q *TermSuggester) MaxTermFreq(maxTermFreq float64) *TermSuggester + func (q *TermSuggester) MinDocFreq(minDocFreq float64) *TermSuggester + func (q *TermSuggester) MinWordLength(minWordLength int) *TermSuggester + func (q *TermSuggester) Name() string + func (q *TermSuggester) PrefixLength(prefixLength int) *TermSuggester + func (q *TermSuggester) ShardSize(shardSize int) *TermSuggester + func (q *TermSuggester) Size(size int) *TermSuggester + func (q *TermSuggester) Sort(sort string) *TermSuggester + func (q *TermSuggester) Source(includeName bool) (interface{}, error) + func (q *TermSuggester) StringDistance(stringDistance string) *TermSuggester + func (q *TermSuggester) SuggestMode(suggestMode string) *TermSuggester + func (q *TermSuggester) Text(text string) *TermSuggester + type TermVectorsFieldInfo struct + FieldStatistics FieldStatistics + Terms map[string]TermsInfo + type TermsAggregation struct + func NewTermsAggregation() *TermsAggregation + func (a *TermsAggregation) CollectionMode(collectionMode string) *TermsAggregation + func (a *TermsAggregation) Exclude(regexp string) *TermsAggregation + func (a *TermsAggregation) ExcludeValues(values ...interface{}) *TermsAggregation + func (a *TermsAggregation) ExecutionHint(hint string) *TermsAggregation + func (a *TermsAggregation) Field(field string) *TermsAggregation + func (a *TermsAggregation) Include(regexp string) *TermsAggregation + func (a *TermsAggregation) IncludeValues(values ...interface{}) *TermsAggregation + func (a *TermsAggregation) Meta(metaData map[string]interface{}) *TermsAggregation + func (a *TermsAggregation) MinDocCount(minDocCount int) *TermsAggregation + func (a *TermsAggregation) Missing(missing interface{}) *TermsAggregation + func (a *TermsAggregation) NumPartitions(n int) *TermsAggregation + func (a *TermsAggregation) Order(order string, asc bool) *TermsAggregation + func (a *TermsAggregation) OrderByAggregation(aggName string, asc bool) *TermsAggregation + func (a *TermsAggregation) OrderByAggregationAndMetric(aggName, metric string, asc bool) *TermsAggregation + func (a *TermsAggregation) OrderByCount(asc bool) *TermsAggregation + func (a *TermsAggregation) OrderByCountAsc() *TermsAggregation + func (a *TermsAggregation) OrderByCountDesc() *TermsAggregation + func (a *TermsAggregation) OrderByTerm(asc bool) *TermsAggregation + func (a *TermsAggregation) OrderByTermAsc() *TermsAggregation + func (a *TermsAggregation) OrderByTermDesc() *TermsAggregation + func (a *TermsAggregation) Partition(p int) *TermsAggregation + func (a *TermsAggregation) RequiredSize(requiredSize int) *TermsAggregation + func (a *TermsAggregation) Script(script *Script) *TermsAggregation + func (a *TermsAggregation) ShardMinDocCount(shardMinDocCount int) *TermsAggregation + func (a *TermsAggregation) ShardSize(shardSize int) *TermsAggregation + func (a *TermsAggregation) ShowTermDocCountError(showTermDocCountError bool) *TermsAggregation + func (a *TermsAggregation) Size(size int) *TermsAggregation + func (a *TermsAggregation) Source() (interface{}, error) + func (a *TermsAggregation) SubAggregation(name string, subAggregation Aggregation) *TermsAggregation + func (a *TermsAggregation) ValueType(valueType string) *TermsAggregation + type TermsAggregationIncludeExclude struct + Exclude string + ExcludeValues []interface{} + Include string + IncludeValues []interface{} + NumPartitions int + Partition int + type TermsInfo struct + DocFreq int64 + Score float64 + TermFreq int64 + Tokens []TokenInfo + Ttf int64 + type TermsLookup struct + func NewTermsLookup() *TermsLookup + func (t *TermsLookup) Id(id string) *TermsLookup + func (t *TermsLookup) Index(index string) *TermsLookup + func (t *TermsLookup) Path(path string) *TermsLookup + func (t *TermsLookup) Routing(routing string) *TermsLookup + func (t *TermsLookup) Source() (interface{}, error) + func (t *TermsLookup) Type(typ string) *TermsLookup + type TermsOrder struct + Ascending bool + Field string + func (order *TermsOrder) Source() (interface{}, error) + type TermsQuery struct + func NewTermsQuery(name string, values ...interface{}) *TermsQuery + func (q *TermsQuery) Boost(boost float64) *TermsQuery + func (q *TermsQuery) QueryName(queryName string) *TermsQuery + func (q *TermsQuery) Source() (interface{}, error) + func (q *TermsQuery) TermsLookup(lookup *TermsLookup) *TermsQuery + type TermsSetQuery struct + func NewTermsSetQuery(name string, values ...interface{}) *TermsSetQuery + func (q *TermsSetQuery) Boost(boost float64) *TermsSetQuery + func (q *TermsSetQuery) MinimumShouldMatchField(minimumShouldMatchField string) *TermsSetQuery + func (q *TermsSetQuery) MinimumShouldMatchScript(minimumShouldMatchScript *Script) *TermsSetQuery + func (q *TermsSetQuery) QueryName(queryName string) *TermsSetQuery + func (q *TermsSetQuery) Source() (interface{}, error) + type TermvectorsFilterSettings struct + func NewTermvectorsFilterSettings() *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MaxDocFreq(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MaxNumTerms(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MaxTermFreq(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MaxWordLength(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MinDocFreq(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MinTermFreq(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) MinWordLength(value int64) *TermvectorsFilterSettings + func (fs *TermvectorsFilterSettings) Source() (interface{}, error) + type TermvectorsResponse struct + Found bool + Id string + Index string + TermVectors map[string]TermVectorsFieldInfo + Took int64 + Type string + Version int + type TermvectorsService struct + func NewTermvectorsService(client *Client) *TermvectorsService + func (s *TermvectorsService) BodyJson(body interface{}) *TermvectorsService + func (s *TermvectorsService) BodyString(body string) *TermvectorsService + func (s *TermvectorsService) Dfs(dfs bool) *TermvectorsService + func (s *TermvectorsService) Do(ctx context.Context) (*TermvectorsResponse, error) + func (s *TermvectorsService) Doc(doc interface{}) *TermvectorsService + func (s *TermvectorsService) FieldStatistics(fieldStatistics bool) *TermvectorsService + func (s *TermvectorsService) Fields(fields ...string) *TermvectorsService + func (s *TermvectorsService) Filter(filter *TermvectorsFilterSettings) *TermvectorsService + func (s *TermvectorsService) Id(id string) *TermvectorsService + func (s *TermvectorsService) Index(index string) *TermvectorsService + func (s *TermvectorsService) Offsets(offsets bool) *TermvectorsService + func (s *TermvectorsService) Parent(parent string) *TermvectorsService + func (s *TermvectorsService) Payloads(payloads bool) *TermvectorsService + func (s *TermvectorsService) PerFieldAnalyzer(perFieldAnalyzer map[string]string) *TermvectorsService + func (s *TermvectorsService) Positions(positions bool) *TermvectorsService + func (s *TermvectorsService) Preference(preference string) *TermvectorsService + func (s *TermvectorsService) Pretty(pretty bool) *TermvectorsService + func (s *TermvectorsService) Realtime(realtime bool) *TermvectorsService + func (s *TermvectorsService) Routing(routing string) *TermvectorsService + func (s *TermvectorsService) TermStatistics(termStatistics bool) *TermvectorsService + func (s *TermvectorsService) Type(typ string) *TermvectorsService + func (s *TermvectorsService) Validate() error + func (s *TermvectorsService) Version(version interface{}) *TermvectorsService + func (s *TermvectorsService) VersionType(versionType string) *TermvectorsService + type TokenInfo struct + EndOffset int64 + Payload string + Position int64 + StartOffset int64 + type TopHitsAggregation struct + func NewTopHitsAggregation() *TopHitsAggregation + func (a *TopHitsAggregation) DocvalueField(docvalueField string) *TopHitsAggregation + func (a *TopHitsAggregation) DocvalueFields(docvalueFields ...string) *TopHitsAggregation + func (a *TopHitsAggregation) Explain(explain bool) *TopHitsAggregation + func (a *TopHitsAggregation) FetchSource(fetchSource bool) *TopHitsAggregation + func (a *TopHitsAggregation) FetchSourceContext(fetchSourceContext *FetchSourceContext) *TopHitsAggregation + func (a *TopHitsAggregation) From(from int) *TopHitsAggregation + func (a *TopHitsAggregation) Highlight(highlight *Highlight) *TopHitsAggregation + func (a *TopHitsAggregation) Highlighter() *Highlight + func (a *TopHitsAggregation) NoStoredFields() *TopHitsAggregation + func (a *TopHitsAggregation) ScriptField(scriptField *ScriptField) *TopHitsAggregation + func (a *TopHitsAggregation) ScriptFields(scriptFields ...*ScriptField) *TopHitsAggregation + func (a *TopHitsAggregation) Size(size int) *TopHitsAggregation + func (a *TopHitsAggregation) Sort(field string, ascending bool) *TopHitsAggregation + func (a *TopHitsAggregation) SortBy(sorter ...Sorter) *TopHitsAggregation + func (a *TopHitsAggregation) SortWithInfo(info SortInfo) *TopHitsAggregation + func (a *TopHitsAggregation) Source() (interface{}, error) + func (a *TopHitsAggregation) TrackScores(trackScores bool) *TopHitsAggregation + func (a *TopHitsAggregation) Version(version bool) *TopHitsAggregation + type TypeQuery struct + func NewTypeQuery(typ string) *TypeQuery + func (q *TypeQuery) Source() (interface{}, error) + type UpdateByQueryService struct + func NewUpdateByQueryService(client *Client) *UpdateByQueryService + func (s *UpdateByQueryService) AbortOnVersionConflict() *UpdateByQueryService + func (s *UpdateByQueryService) AllowNoIndices(allowNoIndices bool) *UpdateByQueryService + func (s *UpdateByQueryService) AnalyzeWildcard(analyzeWildcard bool) *UpdateByQueryService + func (s *UpdateByQueryService) Analyzer(analyzer string) *UpdateByQueryService + func (s *UpdateByQueryService) Body(body string) *UpdateByQueryService + func (s *UpdateByQueryService) Conflicts(conflicts string) *UpdateByQueryService + func (s *UpdateByQueryService) DF(df string) *UpdateByQueryService + func (s *UpdateByQueryService) DefaultOperator(defaultOperator string) *UpdateByQueryService + func (s *UpdateByQueryService) Do(ctx context.Context) (*BulkIndexByScrollResponse, error) + func (s *UpdateByQueryService) DoAsync(ctx context.Context) (*StartTaskResult, error) + func (s *UpdateByQueryService) DocvalueFields(docvalueFields ...string) *UpdateByQueryService + func (s *UpdateByQueryService) ExpandWildcards(expandWildcards string) *UpdateByQueryService + func (s *UpdateByQueryService) Explain(explain bool) *UpdateByQueryService + func (s *UpdateByQueryService) FielddataFields(fielddataFields ...string) *UpdateByQueryService + func (s *UpdateByQueryService) From(from int) *UpdateByQueryService + func (s *UpdateByQueryService) IgnoreUnavailable(ignoreUnavailable bool) *UpdateByQueryService + func (s *UpdateByQueryService) Index(index ...string) *UpdateByQueryService + func (s *UpdateByQueryService) Lenient(lenient bool) *UpdateByQueryService + func (s *UpdateByQueryService) LowercaseExpandedTerms(lowercaseExpandedTerms bool) *UpdateByQueryService + func (s *UpdateByQueryService) Pipeline(pipeline string) *UpdateByQueryService + func (s *UpdateByQueryService) Preference(preference string) *UpdateByQueryService + func (s *UpdateByQueryService) Pretty(pretty bool) *UpdateByQueryService + func (s *UpdateByQueryService) ProceedOnVersionConflict() *UpdateByQueryService + func (s *UpdateByQueryService) Q(q string) *UpdateByQueryService + func (s *UpdateByQueryService) Query(query Query) *UpdateByQueryService + func (s *UpdateByQueryService) Refresh(refresh string) *UpdateByQueryService + func (s *UpdateByQueryService) RequestCache(requestCache bool) *UpdateByQueryService + func (s *UpdateByQueryService) RequestsPerSecond(requestsPerSecond int) *UpdateByQueryService + func (s *UpdateByQueryService) Routing(routing ...string) *UpdateByQueryService + func (s *UpdateByQueryService) Script(script *Script) *UpdateByQueryService + func (s *UpdateByQueryService) Scroll(scroll string) *UpdateByQueryService + func (s *UpdateByQueryService) ScrollSize(scrollSize int) *UpdateByQueryService + func (s *UpdateByQueryService) SearchTimeout(searchTimeout string) *UpdateByQueryService + func (s *UpdateByQueryService) SearchType(searchType string) *UpdateByQueryService + func (s *UpdateByQueryService) Size(size int) *UpdateByQueryService + func (s *UpdateByQueryService) Sort(sort ...string) *UpdateByQueryService + func (s *UpdateByQueryService) SortByField(field string, ascending bool) *UpdateByQueryService + func (s *UpdateByQueryService) Stats(stats ...string) *UpdateByQueryService + func (s *UpdateByQueryService) StoredFields(storedFields ...string) *UpdateByQueryService + func (s *UpdateByQueryService) SuggestField(suggestField string) *UpdateByQueryService + func (s *UpdateByQueryService) SuggestMode(suggestMode string) *UpdateByQueryService + func (s *UpdateByQueryService) SuggestSize(suggestSize int) *UpdateByQueryService + func (s *UpdateByQueryService) SuggestText(suggestText string) *UpdateByQueryService + func (s *UpdateByQueryService) TerminateAfter(terminateAfter int) *UpdateByQueryService + func (s *UpdateByQueryService) Timeout(timeout string) *UpdateByQueryService + func (s *UpdateByQueryService) TimeoutInMillis(timeoutInMillis int) *UpdateByQueryService + func (s *UpdateByQueryService) TrackScores(trackScores bool) *UpdateByQueryService + func (s *UpdateByQueryService) Type(typ ...string) *UpdateByQueryService + func (s *UpdateByQueryService) Validate() error + func (s *UpdateByQueryService) Version(version bool) *UpdateByQueryService + func (s *UpdateByQueryService) VersionType(versionType bool) *UpdateByQueryService + func (s *UpdateByQueryService) WaitForActiveShards(waitForActiveShards string) *UpdateByQueryService + func (s *UpdateByQueryService) WaitForCompletion(waitForCompletion bool) *UpdateByQueryService + func (s *UpdateByQueryService) XSource(xSource ...string) *UpdateByQueryService + func (s *UpdateByQueryService) XSourceExclude(xSourceExclude ...string) *UpdateByQueryService + func (s *UpdateByQueryService) XSourceInclude(xSourceInclude ...string) *UpdateByQueryService + type UpdateResponse struct + ForcedRefresh bool + GetResult *GetResult + Id string + Index string + PrimaryTerm int64 + Result string + SeqNo int64 + Shards *shardsInfo + Status int + Type string + Version int64 + type UpdateService struct + func NewUpdateService(client *Client) *UpdateService + func (b *UpdateService) DetectNoop(detectNoop bool) *UpdateService + func (b *UpdateService) Do(ctx context.Context) (*UpdateResponse, error) + func (b *UpdateService) Doc(doc interface{}) *UpdateService + func (b *UpdateService) DocAsUpsert(docAsUpsert bool) *UpdateService + func (b *UpdateService) Fields(fields ...string) *UpdateService + func (b *UpdateService) Id(id string) *UpdateService + func (b *UpdateService) Index(name string) *UpdateService + func (b *UpdateService) Parent(parent string) *UpdateService + func (b *UpdateService) Pretty(pretty bool) *UpdateService + func (b *UpdateService) Refresh(refresh string) *UpdateService + func (b *UpdateService) RetryOnConflict(retryOnConflict int) *UpdateService + func (b *UpdateService) Routing(routing string) *UpdateService + func (b *UpdateService) Script(script *Script) *UpdateService + func (b *UpdateService) ScriptedUpsert(scriptedUpsert bool) *UpdateService + func (b *UpdateService) Timeout(timeout string) *UpdateService + func (b *UpdateService) Type(typ string) *UpdateService + func (b *UpdateService) Upsert(doc interface{}) *UpdateService + func (b *UpdateService) Version(version int64) *UpdateService + func (b *UpdateService) VersionType(versionType string) *UpdateService + func (b *UpdateService) WaitForActiveShards(waitForActiveShards string) *UpdateService + func (s *UpdateService) FetchSource(fetchSource bool) *UpdateService + func (s *UpdateService) FetchSourceContext(fetchSourceContext *FetchSourceContext) *UpdateService + type ValidateResponse struct + Explanations []interface{} + Shards map[string]interface{} + Valid bool + type ValidateService struct + func NewValidateService(client *Client) *ValidateService + func (s *ValidateService) AllShards(allShards *bool) *ValidateService + func (s *ValidateService) AllowNoIndices(allowNoIndices bool) *ValidateService + func (s *ValidateService) AnalyzeWildcard(analyzeWildcard bool) *ValidateService + func (s *ValidateService) Analyzer(analyzer string) *ValidateService + func (s *ValidateService) BodyJson(body interface{}) *ValidateService + func (s *ValidateService) BodyString(body string) *ValidateService + func (s *ValidateService) DefaultOperator(defaultOperator string) *ValidateService + func (s *ValidateService) Df(df string) *ValidateService + func (s *ValidateService) Do(ctx context.Context) (*ValidateResponse, error) + func (s *ValidateService) ExpandWildcards(expandWildcards string) *ValidateService + func (s *ValidateService) Explain(explain *bool) *ValidateService + func (s *ValidateService) IgnoreUnavailable(ignoreUnavailable bool) *ValidateService + func (s *ValidateService) Index(index ...string) *ValidateService + func (s *ValidateService) Lenient(lenient bool) *ValidateService + func (s *ValidateService) Pretty(pretty bool) *ValidateService + func (s *ValidateService) Q(q string) *ValidateService + func (s *ValidateService) Query(query Query) *ValidateService + func (s *ValidateService) Rewrite(rewrite *bool) *ValidateService + func (s *ValidateService) Type(typ ...string) *ValidateService + func (s *ValidateService) Validate() error + type ValueCountAggregation struct + func NewValueCountAggregation() *ValueCountAggregation + func (a *ValueCountAggregation) Field(field string) *ValueCountAggregation + func (a *ValueCountAggregation) Format(format string) *ValueCountAggregation + func (a *ValueCountAggregation) Meta(metaData map[string]interface{}) *ValueCountAggregation + func (a *ValueCountAggregation) Script(script *Script) *ValueCountAggregation + func (a *ValueCountAggregation) Source() (interface{}, error) + func (a *ValueCountAggregation) SubAggregation(name string, subAggregation Aggregation) *ValueCountAggregation + type WeightFactorFunction struct + func NewWeightFactorFunction(weight float64) *WeightFactorFunction + func (fn *WeightFactorFunction) GetWeight() *float64 + func (fn *WeightFactorFunction) Name() string + func (fn *WeightFactorFunction) Source() (interface{}, error) + func (fn *WeightFactorFunction) Weight(weight float64) *WeightFactorFunction + type WildcardQuery struct + func NewWildcardQuery(name, wildcard string) *WildcardQuery + func (q *WildcardQuery) Boost(boost float64) *WildcardQuery + func (q *WildcardQuery) QueryName(queryName string) *WildcardQuery + func (q *WildcardQuery) Rewrite(rewrite string) *WildcardQuery + func (q *WildcardQuery) Source() (interface{}, error) + type ZeroBackoff struct + func (b ZeroBackoff) Next(retry int) (time.Duration, bool) Other modules containing this package gopkg.in/nextdoor/elastic.v1 gopkg.in/nextdoor/elastic.v10003 gopkg.in/nextdoor/elastic.v10005 gopkg.in/nextdoor/elastic.v2 gopkg.in/nextdoor/elastic.v3 gopkg.in/nextdoor/elastic.v5