Versions in this module Expand all Collapse all v1 v1.1.5 Mar 31, 2025 Changes in this version + type ErrorDetail struct + Reason string + RootCause []RootCause + Type string + type InternalError struct + Error *ErrorDetail + Status int + type RootCause struct + Reason string + Type string v1.1.4 Mar 14, 2025 v1.1.3 Feb 28, 2025 v1.1.2 Feb 17, 2025 Changes in this version + func UpdateBulkMetadata(action string, scannedByte []byte, index, typeName, id string) (newBytes []byte, err error) type View + Builtin bool + ComplexFields string v1.1.0 Jan 11, 2025 Changes in this version type API + ClusterAllocationExplain func(ctx context.Context, body []byte, params url.Values) ([]byte, error) v1.0.0 Dec 16, 2024 Changes in this version + const Easysearch + const Elasticsearch + const ElasticsearchConfigSourceElasticsearch + const ElasticsearchConfigSourceFile + const GlobalSystemElasticsearchID + const KVElasticClusterSettings + const KVElasticIndexMetadata + const KVElasticNodeMetadata + const ModeAgent + const ModeAgentless + const Opensearch + const PartitionByDate + const PartitionByKeyword + const PartitionByNumber + const QueueElasticIndexHealthStatus + const QueueElasticIndexState + var ActionCreate = "create" + var ActionDelete = "delete" + var ActionEnd = []byte("\"") + var ActionIndex = "index" + var ActionStart = []byte("\"") + var ActionUpdate = "update" + var Actions = []string + var DefaultBulkProcessorConfig = BulkProcessorConfig + var NEWLINEBYTES = []byte("\n") + func Abs(x int) int + func BuildSearchHighlight(highlightParam *SearchHighlightParam) util.MapStr + func BuildSearchTermAggregations(params []SearchAggParam) util.MapStr + func BuildSearchTermFilter(filterParam SearchFilterParam) []util.MapStr + func GetDateHistogramIntervalField(distribution, version string, bucketSize string) (string, error) + func GetIndexTypes(client API, indexName string) (map[string]interface{}, error) + func GetShardID(esMajorVersion int, docID []byte, numberOfShards int) int + func GetShardIDWithRoutingOffset(esMajorVersion int, docID []byte, numberOfShards int, routingNumShards int, ...) int + func IsHostAvailable(host string) bool + func IsHostDead(host string) bool + func ParseActionMeta(data []byte) (action, index, typeName, id, routing string, err error) + func ParseUrlLevelBulkMeta(pathStr string) (urlLevelIndex, urlLevelType string) + func RegisterInstance(cfg ElasticsearchConfig, handler API) + func RegisterMetadataChangeEvent(evt MetadataChangeEvent) + func RemoveDotFromIndexName(indexName, dotReplaceTo string) string + func RemoveHostsByClusterID(clusterID string) + func RemoveInstance(elastic string) + func SafetyAddNewlineBetweenData(buffer *bytebufferpool.ByteBuffer, data []byte) + func SetMetadata(k string, v *ElasticsearchMetadata) + func UpdateClient(cfg ElasticsearchConfig, handler API) + func UpdateConfig(cfg ElasticsearchConfig) + func ValidateBulkRequest(where, body string) + func WalkBulkRequests(data []byte, eachLineFunc func(eachLine []byte) (skipNextLine bool), ...) (int, error) + func WalkConfigs(walkFunc func(key, value interface{}) bool) + func WalkHosts(walkFunc func(key, value interface{}) bool) + func WalkMetadata(walkFunc func(key, value interface{}) bool) + type AAIR_Alias struct + Indices []string + Name string + type AAIR_Indices struct + Aliases []string + Attributes []string + Name string + type API interface + Alias func(body []byte) error + Bulk func(data []byte) (*util.Result, error) + CatNodes func(colStr string) ([]CatNodeResponse, error) + CatShards func() ([]CatShardResponse, error) + CatShardsSpecEndpoint func(endPoint string) ([]CatShardResponse, error) + ClusterHealth func(ctx context.Context) (*ClusterHealth, error) + ClusterHealthSpecEndpoint func(ctx context.Context, endPoint string, level string) (*ClusterHealth, error) + Count func(ctx context.Context, indexName string, body []byte) (*CountResponse, error) + CreateIndex func(name string, settings map[string]interface{}) error + Delete func(indexName, docType, id string, refresh ...string) (*DeleteResponse, error) + DeleteByQuery func(indexName string, body []byte) (*DeleteByQueryResponse, error) + DeleteILMPolicy func(target string) error + DeleteIndex func(name string) error + DeleteSearchTemplate func(templateID string) error + Exists func(target string) (bool, error) + FieldCaps func(target string) ([]byte, error) + Flush func(indexName string) ([]byte, error) + Forcemerge func(indexName string, maxCount int) error + Get func(indexName, docType, id string) (*GetResponse, error) + GetAliases func() (*map[string]AliasInfo, error) + GetAliasesAndIndices func() (*AliasAndIndicesResponse, error) + GetAliasesDetail func() (*map[string]AliasDetailInfo, error) + GetClusterSettings func(values url.Values) (map[string]interface{}, error) + GetClusterState func() (*ClusterState, error) + GetClusterStats func(ctx context.Context, node string) (*ClusterStats, error) + GetClusterStatsSpecEndpoint func(ctx context.Context, node string, endPoint string) (*ClusterStats, error) + GetILMPolicy func(target string) (map[string]interface{}, error) + GetIndex func(indexName string) (map[string]interface{}, error) + GetIndexRoutingTable func(index string) (map[string][]IndexShardRouting, error) + GetIndexSettings func(indexNames string) (*util.MapStr, error) + GetIndexStats func(indexName string) (*util.MapStr, error) + GetIndices func(pattern string) (*map[string]IndexInfo, error) + GetIndicesStats func() *IndicesStats + GetMajorVersion func() int + GetNodeInfo func(nodeID string) (*NodesInfo, error) + GetNodes func() (*map[string]NodesInfo, error) + GetNodesStats func(nodeID, host string, level string) *NodesStats + GetPrimaryShards func() (*map[string]map[int]ShardInfo, error) + GetRemoteInfo func() ([]byte, error) + GetStats func() (*Stats, error) + GetVersion func() Version + Index func(indexName, docType string, id interface{}, data interface{}, refresh string) (*InsertResponse, error) + IndexExists func(indexName string) (bool, error) + InitDefaultTemplate func(templateName, indexPrefix string) + PutILMPolicy func(target string, policyConfig []byte) error + QueryDSL func(ctx context.Context, indexName string, queryArgs *[]util.KV, queryDSL []byte) (*SearchResponse, error) + Refresh func(name string) (err error) + Reindex func(body []byte) (*ReindexResponse, error) + RenderTemplate func(body map[string]interface{}) ([]byte, error) + Search func(indexName string, query *SearchRequest) (*SearchResponse, error) + SearchTasksByIds func(ids []string) (*SearchResponse, error) + SearchTemplate func(body map[string]interface{}) ([]byte, error) + SearchWithRawQueryDSL func(indexName string, queryDSL []byte) (*SearchResponse, error) + SetSearchTemplate func(templateID string, body []byte) error + Update func(indexName, docType string, id interface{}, data interface{}, refresh string) (*InsertResponse, error) + UpdateByQuery func(indexName string, body []byte) (*UpdateByQueryResponse, error) + UpdateClusterSettings func(body []byte) error + UpdateIndexSettings func(indexName string, settings map[string]interface{}) error + func GetClient(k string) API + func GetClientNoPanic(k string) API + type APIContext struct + Client *fasthttp.Client + Request *fasthttp.Request + Response *fasthttp.Response + type Aggregation struct + type AggregationRequest struct + Aggregations map[string]Aggregation + type AggregationResponse struct + Buckets []BucketBase + Value interface{} + type AliasAction map[string]map[string]interface + type AliasActionBody struct + Alias string + Filter map[string]interface{} + Index string + IndexRouting string + Indices []string + IsWriteIndex bool + Routing string + SearchRouting string + type AliasAndIndicesResponse struct + Aliases []AAIR_Alias + Indices []AAIR_Indices + type AliasDetailInfo struct + Alias string + Indexes []AliasIndex + WriteIndex string + type AliasIndex struct + Filter interface{} + Index string + IndexRouting string + IsHidden bool + IsWriteIndex bool + SearchRouting string + type AliasInfo struct + Alias string + Index []string + WriteIndex string + type AliasRequest struct + Actions []AliasAction + type BoolQuery struct + Must []interface{} + MustNot []interface{} + Should []interface{} + type BoundValuesResult struct + Max float64 + Min float64 + NotExistsFilter map[string]interface{} + Null int64 + type Bucket struct + DocCount int64 + Key interface{} + KeyAsString interface{} + type BucketBase map[string]interface + type BulkActionMetadata struct + Create *BulkIndexMetadata + Delete *BulkIndexMetadata + Index *BulkIndexMetadata + Stats int + Update *BulkIndexMetadata + func (meta *BulkActionMetadata) GetItem() *BulkIndexMetadata + type BulkBuffer struct + MessageIDs []string + Queue string + Reason []string + func (receiver *BulkBuffer) Add(id string, data []byte) + func (receiver *BulkBuffer) GetMessageBytes() []byte + func (receiver *BulkBuffer) GetMessageCount() int + func (receiver *BulkBuffer) GetMessageSize() int + func (receiver *BulkBuffer) Reset() + func (receiver *BulkBuffer) ResetData() + func (receiver *BulkBuffer) SafetyEndWithNewline() + func (receiver *BulkBuffer) Write(data []byte) + func (receiver *BulkBuffer) WriteByteBuffer(data []byte) + func (receiver *BulkBuffer) WriteErrorReason(reason string) + func (receiver *BulkBuffer) WriteMessageID(id string) + func (receiver *BulkBuffer) WriteNewByteBufferLine(tag string, data []byte) + func (receiver *BulkBuffer) WriteStringBuffer(data string) + type BulkBufferPool struct + func NewBulkBufferPool(tag string, maxSize, maxItems uint32) *BulkBufferPool + func (pool *BulkBufferPool) AcquireBulkBuffer() *BulkBuffer + func (pool *BulkBufferPool) ReturnBulkBuffer(item *BulkBuffer) + type BulkDetail struct + Failure BulkDetailItem + Invalid BulkDetailItem + type BulkDetailItem struct + Documents []string + Reasons []string + type BulkIndexMetadata struct + ID string + Index string + Parent1 interface{} + Parent2 interface{} + Pipeline string + PrimaryTerm int64 + Refresh string + RequireAlias interface{} + Result string + RetryOnConflict interface{} + Routing1 interface{} + Routing2 interface{} + SeqNo int64 + Shards *struct{} + Source interface{} + SourceExcludes interface{} + SourceIncludes interface{} + Type string + Version1 interface{} + Version2 interface{} + type BulkProcessor struct + BulkBufferPool *BulkBufferPool + Config BulkProcessorConfig + HttpPool *fasthttp.RequestResponsePool + func NewBulkProcessor(tag, esClusterID string, cfg BulkProcessorConfig) BulkProcessor + func (joint *BulkProcessor) Bulk(ctx context.Context, tag string, metadata *ElasticsearchMetadata, host string, ...) (continueNext bool, statsRet map[int]int, bulkResult *BulkResult, err error) + type BulkProcessorConfig struct + BulkMaxDocsCount int + BulkResponseParseConfig BulkResponseParseConfig + BulkSizeInKb int + BulkSizeInMb int + Compress bool + DeadletterRequestsQueue string + InvalidRequestsQueue string + MaxRejectRetryTimes int + RejectDelayInSeconds int + RemoveDuplicatedNewlines bool + RequestTimeoutInSecond int + RetryDelayInSeconds int + RetryRules RetryRules + func (this *BulkProcessorConfig) GetBulkSizeInBytes() int + type BulkResponse struct + Errors bool + Items []BulkActionMetadata + Took int + type BulkResponseParseConfig struct + BulkResultMessageMaxRequestBodyLength int + BulkResultMessageMaxResponseBodyLength int + BulkResultMessageQueue string + IncludeActionStats bool + IncludeErrorDetails bool + IncludeIndexStats bool + MaxItemOfErrorDetailsCount int + OutputBulkStats bool + OutputVersions bool + ResultVersionsQueueName string + SaveBusyBulkResultToMessageQueue bool + SaveErrorBulkResultToMessageQueue bool + SaveSuccessBulkResultToMessageQueue bool + type BulkResult struct + Actions []string + Codes []int + Detail BulkDetail + Error bool + ErrorMsgs []string + Indices []string + Stats BulkStats + Summary BulkSummary + Versions []VersionInfo + func HandleBulkResponse(req *fasthttp.Request, resp *fasthttp.Response, tag util.MapStr, ...) (bool, map[int]int, *BulkResult) + type BulkStats struct + Actions map[string]int + Code map[int]int + Indices map[string]int + type BulkSummary struct + Failure BulkSummaryItem + Invalid BulkSummaryItem + Success BulkSummaryItem + type BulkSummaryItem struct + Count int + Size int + type CatIndexResponse struct + DocsCount string + DocsDeleted string + Health string + Index string + Pri string + PriStoreSize string + Rep string + SegmentCount string + Status string + StoreSize string + Uuid string + type CatNodeResponse struct + Cpu string + DiskAvail string + DiskUsed string + HeapMax string + HeapPercent string + Id string + Ip string + Load15M interface{} + Load1M string + Load5M interface{} + Master string + Name string + NodeRole string + Port string + RamPercent string + Shards int + Uptime string + type CatShardResponse struct + Docs string + Index string + NodeID string + NodeIP string + NodeName string + ShardID string + ShardType string + State string + Store string + StoreInBytes int64 + UnassignedReason string + type ClusterHealth struct + ActivePrimary_shards int + ActiveShards int + ActiveShardsPercentAsNumber float64 + DelayedUnassignedShards int + Indices map[string]map[string]interface{} + InitializingShards int + Name string + NumberOfInFlightFetch int + NumberOfNodes int + NumberOfPendingTasks int + NumberOf_data_nodes int + RelocatingShards int + Status string + TaskMaxWaitingInQueueMillis float64 + TimedOut bool + UnassignedShards int + type ClusterInformation struct + ClusterName string + ClusterUUID string + Name string + Version struct{ ... } + type ClusterRoutingTable struct + Indices map[string]struct{ ... } + type ClusterState struct + ClusterName string + ClusterUUID string + CompressedSizeInBytes int + MasterNode string + Metadata ... + RoutingTable *ClusterRoutingTable + StateUUID string + Version int64 + type ClusterStateNodes struct + Attributes map[string]interface{} + EphemeralId string + Name string + TransportAddress string + type ClusterStats struct + ClusterName string + ClusterUUID string + Indices map[string]interface{} + Nodes map[string]interface{} + Status string + Timestamp int64 + type Collapse struct + Field string + type CommandRequest struct + Body string + Method string + Path string + type CommonCommand struct + Created time.Time + ID string + Requests []CommandRequest + Tag []string + Title string + type CountResponse struct + Count int64 + type DeleteByQueryResponse struct + Deleted int64 + Total int64 + type DeleteResponse struct + ID string + Index string + Result string + Shards struct{ ... } + Type string + Version int + type DiscoveryResult struct + Nodes map[string]*LocalNodeInfo + UnknownProcess []model.ProcessInfo + type ElasticField struct + Aggregatable bool + ESTypes []string + Name string + ReadFromDocValues bool + Searchable bool + Type string + func GetFieldCaps(client API, pattern string, metaFields []string) ([]ElasticField, error) + type ElasticFieldType struct + ESTypes []string + Name string + type ElasticsearchConfig struct + AgentBasicAuth *model.BasicAuth + AgentCredentialID string + AllowAccessWhenMasterNotFound bool + BasicAuth *model.BasicAuth + ClientMode string + ClusterUUID string + CredentialID string + Description string + Discovery struct{ ... } + Distribution string + Enabled bool + Endpoint string + Endpoints []string + GeoLocation *GeoLocation + Host string + Hosts []string + HttpProxy string + Labels util.MapStr + MaxCachedSize int64 + MetadataCacheEnabled bool + MetadataConfigs *MetadataConfig + MetricCollectionMode string + MonitorConfigs *MonitorConfig + Monitored bool + Name string + NoDefaultAuthForAgent bool + Order int + Owner []struct{ ... } + Project string + RawName string + RequestCompress bool + RequestTimeout int + Reserved bool + Schema string + SearchText string + Source string + Tags []string + TrafficControl ... + Version string + func GetConfig(k string) *ElasticsearchConfig + func GetConfigNoPanic(k string) *ElasticsearchConfig + func (c *ElasticsearchConfig) GetAnyEndpoint() string + func (c *ElasticsearchConfig) ParseMajorVersion() int + type ElasticsearchMetadata struct + Aliases *map[string]AliasInfo + ClusterState *ClusterState + Config *ElasticsearchConfig + Health *ClusterHealth + IndexSettings map[string]*util.MapStr + IsAgentMode bool + Nodes *map[string]NodesInfo + NodesTopologyVersion int + func GetMetadata(k string) *ElasticsearchMetadata + func GetOrInitMetadata(cfg *ElasticsearchConfig) *ElasticsearchMetadata + func InitMetadata(cfg *ElasticsearchConfig, defaultHealth bool) *ElasticsearchMetadata + func (meta *ElasticsearchMetadata) GetActiveEndpoint() string + func (meta *ElasticsearchMetadata) GetActiveHost() string + func (meta *ElasticsearchMetadata) GetActiveHosts() int + func (meta *ElasticsearchMetadata) GetActivePreferredEndpoint(host string) string + func (meta *ElasticsearchMetadata) GetActivePreferredEndpoints(hosts []string) string + func (meta *ElasticsearchMetadata) GetActivePreferredSeedEndpoint() string + func (meta *ElasticsearchMetadata) GetActivePreferredSeedHost() string + func (meta *ElasticsearchMetadata) GetMajorVersion() int + func (meta *ElasticsearchMetadata) GetNodeInfo(nodeID string) *NodesInfo + func (meta *ElasticsearchMetadata) GetPrimaryShardInfo(index string, shardID string) (*IndexShardRouting, error) + func (meta *ElasticsearchMetadata) GetSchema() string + func (meta *ElasticsearchMetadata) GetSeedHosts() []string + func (meta *ElasticsearchMetadata) Init(health bool) + func (meta *ElasticsearchMetadata) IsAvailable() bool + func (meta *ElasticsearchMetadata) IsTLS() bool + func (meta *ElasticsearchMetadata) PrepareEndpoint(host string) string + func (meta *ElasticsearchMetadata) ReportFailure(errorMessage error) bool + func (meta *ElasticsearchMetadata) ReportSuccess() + func (metadata *ElasticsearchMetadata) CheckNodeTrafficThrottle(node string, req, dataSize, maxWaitInMS int) + func (metadata *ElasticsearchMetadata) GetActivePreferredHost(host string) string + func (metadata *ElasticsearchMetadata) GetHttpClient(host string) *fasthttp.Client + func (metadata *ElasticsearchMetadata) GetIndexPrimaryShardRoutingTable(index string, shard int) (*IndexShardRouting, error) + func (metadata *ElasticsearchMetadata) GetIndexPrimaryShardsRoutingTable(index string) ([]IndexShardRouting, error) + func (metadata *ElasticsearchMetadata) GetIndexRoutingTable(index string) (map[string][]IndexShardRouting, error) + func (metadata *ElasticsearchMetadata) GetIndexSetting(index string) (string, *util.MapStr, error) + func (metadata *ElasticsearchMetadata) GetIndexStats(indexName string) (*util.MapStr, error) + func (metadata *ElasticsearchMetadata) GetValue(s string) (interface{}, error) + func (metadata *ElasticsearchMetadata) LastSuccess() time.Time + func (metadata *ElasticsearchMetadata) NewHttpClient(host string) *fasthttp.Client + type ErrorResponse struct + Error ... + RootCause interface{} + Status int + type EventAction string + const EventActionCreate + const EventActionDelete + const EventActionUpdate + type FieldCap struct + Aggregatable bool + Indices []string + Searchable bool + Type string + type FieldCapsResponse struct + Fields map[string]map[string]FieldCap + Indices []string + type GeoLocation struct + DC string + Provider string + Rack string + Region string + type GetResponse struct + Found bool + ID string + Index string + Source map[string]interface{} + Type string + Version int + type HostMetadata struct + ClusterID string + ID string + Metadata struct{ ... } + NodeID string + Timestamp time.Time + type IndexConfig struct + Fields util.MapStr + ID string + Metadata IndexMetadata + SearchText string + Timestamp time.Time + type IndexDocument struct + Highlight map[string][]interface{} + ID string + Index string + Routing string + Source map[string]interface{} + Type string + type IndexInfo struct + DocsCount int64 + DocsDeleted int64 + Health string + ID string + Index string + PriStoreSize string + Replicas int + SegmentsCount int64 + Shards int + Status string + StoreSize string + type IndexLevelStats struct + Completion struct{ ... } + Docs struct{ ... } + Fielddata struct{ ... } + Flush struct{ ... } + Get struct{ ... } + Indexing struct{ ... } + Merges struct{ ... } + QueryCache struct{ ... } + Recovery struct{ ... } + Refresh struct{ ... } + RequestCache struct{ ... } + Search struct{ ... } + Segments struct{ ... } + Store struct{ ... } + Translog struct{ ... } + Warmer struct{ ... } + type IndexMetadata struct + Aliases interface{} + Category string + ClusterID string + ClusterName string + IndexID string + IndexName string + Labels util.MapStr + Tags []interface{} + type IndexShardRouting struct + AllocationId ... + Index string + Node string + Primary bool + RecoverySource ... + RelocatingNode interface{} + Shard int + State string + UnassignedInfo ... + Version int + type IndexStats struct + All struct{ ... } + type IndicesStats struct + Nodes map[string]interface{} + type InsertResponse struct + ID string + Index string + Result string + Shards struct{ ... } + Type string + Version int + type LocalNodeInfo struct + ClusterID string + ClusterInfo *ClusterInformation + Enrolled bool + NodeInfo *NodesInfo + NodeUUID string + Status string + type MappingAPI interface + GetMapping func(copyAllIndexes bool, indexNames string) (string, int, *util.MapStr, error) + UpdateMapping func(indexName string, docType string, mappings []byte) ([]byte, error) + type MatchQuery struct + Match map[string]interface{} + func (match *MatchQuery) Set(field string, v interface{}) + type MetadataChangeEvent func(meta *ElasticsearchMetadata, action EventAction) + type MetadataConfig struct + ClusterSettingsCheck TaskConfig + HealthCheck TaskConfig + MetadataRefresh TaskConfig + NodeAvailabilityCheck TaskConfig + type MonitorConfig struct + ClusterHealth TaskConfig + ClusterStats TaskConfig + IndexStats TaskConfig + NodeStats TaskConfig + type NodeAvailable struct + ClusterID string + Host string + func GetHostAvailableInfo(host string) (*NodeAvailable, bool) + func GetOrInitHost(host string, clusterID string) *NodeAvailable + func (node *NodeAvailable) FailureTickets() int + func (node *NodeAvailable) IsAvailable() bool + func (node *NodeAvailable) IsDead() bool + func (node *NodeAvailable) LastCheck() time.Time + func (node *NodeAvailable) LastSuccess() time.Time + func (node *NodeAvailable) ReportFailure() + func (node *NodeAvailable) ReportSuccess() + type NodeConfig struct + ID string + Metadata NodeMetadata + Payload NodePayload + SearchText string + Timestamp time.Time + type NodeMetadata struct + Category string + ClusterID string + ClusterName string + Host string + Labels util.MapStr + NodeID string + NodeName string + Tags []string + type NodePayload struct + NodeInfo *NodesInfo + type NodesInfo struct + Aggregations map[string]interface{} + Attributes map[string]interface{} + BuildFlavor string + BuildHash string + BuildType string + Host string + Http struct{ ... } + Ingest map[string]interface{} + Ip string + Jvm map[string]interface{} + Modules []map[string]interface{} + Name string + Os map[string]interface{} + Plugins []interface{} + Process struct{ ... } + Roles []string + Settings map[string]interface{} + ThreadPool map[string]interface{} + TotalIndexingBuffer int64 + Transport struct{ ... } + TransportAddress string + Version string + func (node *NodesInfo) GetHttpPublishHost() string + func (node *NodesInfo) GetPathLogs() string + type NodesResponse struct + ClusterName string + Nodes map[string]NodesInfo + NodesCount map[string]interface{} + type NodesStats struct + Nodes map[string]interface{} + type PartitionInfo struct + Docs int64 + End float64 + Filter map[string]interface{} + Key float64 + Other bool + Start float64 + func GetPartitions(q *PartitionQuery, client API) ([]PartitionInfo, error) + func MergePartitions(sourcePartitions []PartitionInfo, targetPartitions []PartitionInfo, ...) []PartitionInfo + type PartitionQuery struct + DocType string + FieldName string + FieldType string + Filter interface{} + IndexName string + Step interface{} + type Query struct + BoolQuery *BoolQuery + func (q *Query) Must(query interface{}) + type QueryStringQuery struct + Query map[string]interface{} + func NewQueryString(q string) *QueryStringQuery + func (query *QueryStringQuery) DefaultOperator(op string) + func (query *QueryStringQuery) Fields(fields ...string) + func (query *QueryStringQuery) QueryString(q string) + type RangeQuery struct + Range map[string]map[string]interface{} + func (query *RangeQuery) Gt(field string, value interface{}) + func (query *RangeQuery) Gte(field string, value interface{}) + func (query *RangeQuery) Lt(field string, value interface{}) + func (query *RangeQuery) Lte(field string, value interface{}) + type ReindexResponse struct + Task string + type ReplicationAPI interface + CreateAutoFollowReplication func(autoFollowPatternName string, body []byte) error + DeleteAutoFollowReplication func(autoFollowPatternName string, body []byte) error + GetAutoFollowStats func(autoFollowPatternName string) ([]byte, error) + GetReplicationFollowerStats func(followIndex string) ([]byte, error) + GetReplicationStatus func(followIndex string) ([]byte, error) + PauseReplication func(followIndex string, body []byte) error + ResumeReplication func(followIndex string, body []byte) error + StartReplication func(followIndex string, body []byte) error + StopReplication func(indexName string, body []byte) error + type ResponseBase struct + ESError interface{} + ErrorObject error + RawResult *util.Result + StatusCode int + func (this *ResponseBase) GetBoolByJsonPath(path string) (interface{}, error) + func (this *ResponseBase) GetBytesByJsonPath(path string) ([]byte, error) + func (this *ResponseBase) GetIntByJsonPath(path string) (interface{}, error) + func (this *ResponseBase) GetStringByJsonPath(path string) (interface{}, error) + type RetryRule struct + Keyword []string + Status []int + type RetryRules struct + Default bool + Denied RetryRule + Permitted RetryRule + Retry429 bool + Retry4xx bool + func (this *RetryRules) Retryable(code int, msg string) bool + type ScriptAPI interface + PutScript func(scriptName string, script []byte) ([]byte, error) + ScriptExists func(scriptName string) (bool, error) + SearchByTemplate func(indexName, scriptName string, params map[string]interface{}) (*SearchResponse, error) + type ScrollAPI interface + ClearScroll func(scrollId string) error + NewScroll func(indexNames string, scrollTime string, docBufferCount int, query *SearchRequest, ...) ([]byte, error) + NextScroll func(ctx *APIContext, scrollTime string, scrollId string) ([]byte, error) + type ScrollResponse struct + Hits struct{ ... } + ScrollId string + Shards ShardResponse + TimedOut bool + Took int + func (scroll *ScrollResponse) GetDocs() []IndexDocument + func (scroll *ScrollResponse) GetHitsTotal() int64 + func (scroll *ScrollResponse) GetScrollId() string + func (scroll *ScrollResponse) GetShardResponse() ShardResponse + func (scroll *ScrollResponse) SetScrollId(id string) + func (v *ScrollResponse) UnmarshalEasyJSON(l *jlexer.Lexer) + func (v *ScrollResponse) UnmarshalJSON(data []byte) error + func (v ScrollResponse) MarshalEasyJSON(w *jwriter.Writer) + func (v ScrollResponse) MarshalJSON() ([]byte, error) + type ScrollResponseAPI interface + GetDocs func() []IndexDocument + GetHitsTotal func() int64 + GetScrollId func() string + GetShardResponse func() ShardResponse + SetScrollId func(id string) + type ScrollResponseV7 struct + Hits struct{ ... } + ScrollId string + Shards ShardResponse + TimedOut bool + Took int + func (scroll *ScrollResponseV7) GetDocs() []IndexDocument + func (scroll *ScrollResponseV7) GetHitsTotal() int64 + func (scroll *ScrollResponseV7) GetScrollId() string + func (scroll *ScrollResponseV7) GetShardResponse() ShardResponse + func (scroll *ScrollResponseV7) SetScrollId(id string) + func (v *ScrollResponseV7) UnmarshalEasyJSON(l *jlexer.Lexer) + func (v *ScrollResponseV7) UnmarshalJSON(data []byte) error + func (v ScrollResponseV7) MarshalEasyJSON(w *jwriter.Writer) + func (v ScrollResponseV7) MarshalJSON() ([]byte, error) + type SearchAggParam struct + Field string + TermsAggParams util.MapStr + type SearchFilterParam map[string][]string + type SearchHighlightParam struct + Fields []string + FragmentSize int + NumberOfFragment int + type SearchRequest struct + AggregationRequest *AggregationRequest + Collapse *Collapse + From int + Query *Query + Size int + Sort *[]interface{} + Source interface{} + func GetSearchRequest(querystring, dsl, sourceFields string, sortField, sortType string) *SearchRequest + func (request *SearchRequest) AddSort(field string, order string) + func (request *SearchRequest) Set(key string, value interface{}) error + func (request *SearchRequest) ToJSONString() string + type SearchResponse struct + Aggregations map[string]AggregationResponse + Hits struct{ ... } + TimedOut bool + Took int + func (response *SearchResponse) GetTotal() int64 + type SearchTemplate struct + ClusterID string + Created time.Time + ID string + Name string + Source string + Updated time.Time + type SearchTemplateHistory struct + Action string + Content map[string]interface{} + Created time.Time + ID string + TemplateID string + type SecurityAPI interface + DeleteRole func(roleName string) error + DeleteUser func(username string) error + GetPrivileges func() ([]byte, error) + GetRole func(roleName string) ([]byte, error) + GetRoles func() ([]byte, error) + GetUser func(username string) ([]byte, error) + GetUsers func() ([]byte, error) + PutRole func(roleName string, body []byte) error + PutUser func(username string, body []byte) error + type Setting struct + ClusterID string + ID string + Key string + UpdatedAt time.Time + Value string + type ShardInfo struct + Docs int64 + Index string + NodeID string + NodeIP string + NodeName string + Primary bool + ShardID string + State string + Store string + UnassignedReason string + type ShardResponse struct + Failed int + Failures []struct{ ... } + Skipped int + Successful int + Total int + type Stats struct + All struct{ ... } + Indices map[string]struct{ ... } + type TaskConfig struct + Enabled bool + Interval string + type TemplateAPI interface + GetTemplate func(scriptName string) (map[string]interface{}, error) + PutTemplate func(scriptName string, template []byte) ([]byte, error) + SearchByTemplate func(indexName, scriptName string, params map[string]interface{}) (*SearchResponse, error) + TemplateExists func(scriptName string) (bool, error) + type TermsAggregationQuery struct + func NewTermsAggregation() (query *TermsAggregationQuery) + func (query *TermsAggregationQuery) Field(field string) *TermsAggregationQuery + func (query *TermsAggregationQuery) Size(size int) *TermsAggregationQuery + type TermsQuery struct + Match map[string][]interface{} + func (match *TermsQuery) Set(field string, v []interface{}) + func (match *TermsQuery) SetStringArray(field string, v []string) + type TraceMeta struct + ClusterID string + Index string + TraceID bool + type TraceTemplate struct + AggField string + ClusterID string + Created time.Time + Description string + ID string + MetaIndex string + Name string + TimestampField string + TraceField string + Updated time.Time + type UpdateByQueryResponse struct + Failures []interface{} + Total int64 + Updated int64 + type Version struct + Distribution string + Major int + Number string + type VersionInfo struct + DocOffset int + ID string + Index string + MessageOffset string + MessageTime time.Time + Path string + Payload [][]byte + PrimaryTerm int64 + ReplicationID string + SequenceNumber int64 + Status int64 + ThisMessageOffset queue.Offset + Time time.Time + Version int64 + func (ver *VersionInfo) GetKey() string + type View struct + ClusterID string + DefaultLayoutID string + FieldFormatMap string + Fields string + ID string + TimeFieldName string + Title string + UpdatedAt time.Time + ViewName string + type ViewRequest struct + Attributes View