types

package
v0.12.1 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Nov 17, 2023 License: Apache-2.0 Imports: 4 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type AcknowledgeAlertRequest added in v0.11.0

type AcknowledgeAlertRequest struct {
	Alerts []string `json:"alerts"`
}

type Action added in v0.11.0

type Action struct {
	ID              string          `json:"id"`
	Name            string          `json:"name"`
	DestinationID   string          `json:"destination_id"`
	MessageTemplate MessageTemplate `json:"message_template"`
	ThrottleEnabled bool            `json:"throttle_enabled"`
	SubjectTemplate SubjectTemplate `json:"subject_template"`
}

type ActionExecutionResult added in v0.11.0

type ActionExecutionResult struct {
	ActionID          string `json:"action_id"`
	LastExecutionTime int64  `json:"last_execution_time"`
	ThrottledCount    int    `json:"throttled_count"`
}

type ActionOperation

type ActionOperation struct {
	ForceMerge    *ForceMergeOperation    `json:"force_merge,omitempty"`
	ReadOnly      *ReadOnlyOperation      `json:"read_only,omitempty"`
	ReadWrite     *ReadWriteOperation     `json:"read_write,omitempty"`
	ReplicaCount  *ReplicaCountOperation  `json:"replica_count,omitempty"`
	Close         *CloseOperation         `json:"close,omitempty"`
	Open          *OpenOperation          `json:"open,omitempty"`
	Delete        *DeleteOperation        `json:"delete,omitempty"`
	Rollover      *RolloverOperation      `json:"rollover,omitempty"`
	Notification  *NotificationSpec       `json:"notification,omitempty"`
	Snapshot      *SnapshotOperation      `json:"snapshot,omitempty"`
	IndexPriority *IndexPriorityOperation `json:"index_priority,omitempty"`
	Allocation    *AllocationOperation    `json:"allocation,omitempty"`
}

type ActionSpec

type ActionSpec struct {
	Timeout          string     `json:"timeout,omitempty"`
	Retry            *RetrySpec `json:"retry,omitempty"`
	*ActionOperation `json:",inline,omitempty"`
}

type Alert added in v0.11.0

type Alert struct {
	ID                    string                  `json:"id"`
	Version               int                     `json:"version"`
	MonitorID             string                  `json:"monitor_id"`
	SchemaVersion         int                     `json:"schema_version"`
	MonitorVersion        int                     `json:"monitor_version"`
	MonitorName           string                  `json:"monitor_name"`
	MonitorUser           User                    `json:"monitor_user"`
	TriggerID             string                  `json:"trigger_id"`
	TriggerName           string                  `json:"trigger_name"`
	State                 string                  `json:"state"`
	ErrorMessage          string                  `json:"error_message"`
	AlertHistory          []AlertHistory          `json:"alert_history"`
	Severity              string                  `json:"severity"`
	ActionExecutionResult []ActionExecutionResult `json:"action_execution_results"`
	StartTime             int64                   `json:"start_time"`
	LastNotificationTime  int64                   `json:"last_notification_time"`
	EndTime               *int64                  `json:"end_time"`
	AcknowledgedTime      *int64                  `json:"acknowledged_time"`
}

type AlertHistory added in v0.11.0

type AlertHistory struct {
	Timestamp int64  `json:"timestamp"`
	Message   string `json:"message"`
}

type AliasActionSpec

type AliasActionSpec struct {
	*AliasAtomicAction `json:",inline,omitempty"`
}

type AliasAtomicAction

type AliasAtomicAction struct {
	Add         *AliasGenericAction `json:"add,omitempty"`
	Remove      *AliasGenericAction `json:"remove,omitempty"`
	RemoveIndex *AliasGenericAction `json:"remove_index,omitempty"`
}

type AliasGenericAction

type AliasGenericAction struct {
	Alias         string                 `json:"alias,omitempty"`
	Aliases       []string               `json:"aliases,omitempty"`
	Filter        map[string]interface{} `json:"filter,omitempty"`
	Index         string                 `json:"index,omitempty"`
	Indices       []string               `json:"indices,omitempty"`
	IndexRouting  string                 `json:"index_routing,omitempty"`
	IsHidden      *bool                  `json:"is_hidden,omitempty"`
	IsWriteIndex  *bool                  `json:"is_write_index,omitempty"`
	MustExist     *bool                  `json:"must_exist,omitempty"`
	Routing       string                 `json:"routing,omitempty"`
	SearchRouting string                 `json:"search_routing,omitempty"`
}

type AllocationOperation

type AllocationOperation struct {
	Require map[string]string `json:"require,omitempty"`
	Include map[string]string `json:"include,omitempty"`
	Exclude map[string]string `json:"exclude,omitempty"`
	WaitFor string            `json:"wait_for,omitempty"`
}

type Channel added in v0.11.0

type Channel struct {
	ConfigID          string `json:"config_id"`
	LastUpdatedTimeMS int64  `json:"last_updated_time_ms"`
	CreatedTimeMS     int64  `json:"created_time_ms"`
	Config            struct {
		Name           string        `json:"name"`
		Description    string        `json:"description"`
		ConfigType     string        `json:"config_type"`
		IsEnabled      bool          `json:"is_enabled"`
		SlackDetails   SlackConfig   `json:"slack"`
		WebhookDetails WebhookConfig `json:"webhook"`
	} `json:"config"`
}

type ChimeSpec

type ChimeSpec struct {
	URL string `json:"url"`
}

type CloseOperation

type CloseOperation struct {
}

type ClusterMetadataDoc added in v0.9.1

type ClusterMetadataDoc struct {
	ClusterMetadataDocUpdate

	Id string `json:"id,omitempty"`
}

ClusterMetadataDoc defines the available metadata for each logging data.

type ClusterMetadataDocResponse added in v0.9.1

type ClusterMetadataDocResponse struct {
	Index       string             `json:"_index,omitempty"`
	ID          string             `json:"_id,omitempty"`
	SeqNo       int                `json:"_seq_no,omitempty"`
	PrimaryTerm int                `json:"_primary_term,omitempty"`
	Found       *bool              `json:"found,omitempty"`
	Source      ClusterMetadataDoc `json:"_source,omitempty"`
}

type ClusterMetadataDocUpdate added in v0.9.1

type ClusterMetadataDocUpdate struct {
	Name string `json:"name,omitempty"`
}

type Condition added in v0.11.0

type Condition struct {
	Script struct {
		Source string `json:"source"`
		Lang   string `json:"lang"`
	} `json:"script"`
}

type ConditionSpec

type ConditionSpec struct {
	MinIndexAge string    `json:"min_index_age,omitempty"`
	MinDocCount int       `json:"min_doc_count,omitempty"`
	MinSize     string    `json:"min_size,omitempty"`
	Cron        *CronSpec `json:"cron,omitempty"`
}

type CronObject

type CronObject struct {
	Expression string `json:"expression"`
	Timezone   string `json:"timezone"`
}

type CronSpec

type CronSpec struct {
	Cron CronObject `json:"cron"`
}

type CustomWebhookSpec

type CustomWebhookSpec struct {
	URL string `json:"url"`
}

type DashboardsDocResponse

type DashboardsDocResponse struct {
	Index       string               `json:"_index,omitempty"`
	ID          string               `json:"_id,omitempty"`
	SeqNo       int                  `json:"_seq_no,omitempty"`
	PrimaryTerm int                  `json:"_primary_term,omitempty"`
	Found       *bool                `json:"found,omitempty"`
	Source      DashboardsVersionDoc `json:"_source,omitempty"`
}

type DashboardsVersionDoc

type DashboardsVersionDoc struct {
	DashboardVersion string `json:"version"`
}

type DeleteOperation

type DeleteOperation struct {
}

type DestinationSpec

type DestinationSpec struct {
	DestinationType `json:",inline"`
}

type DestinationType

type DestinationType struct {
	Chime         *ChimeSpec         `json:"chime,omitempty"`
	Slack         *SlackSpec         `json:"slack,omitempty"`
	CustomWebhook *CustomWebhookSpec `json:"custom_webhook,omitempty"`
}

type DynamicTemplateSpec

type DynamicTemplateSpec struct {
	MatchMappingType string           `json:"match_mapping_type,omitempty"`
	Match            string           `json:"match,omitempty"`
	UnMatch          string           `json:"unmatch,omitempty"`
	PathMatch        string           `json:"path_match,omitempty"`
	PathUnMatch      string           `json:"path_unmatch,omitempty"`
	Mapping          PropertySettings `json:"mapping,omitempty"`
}

type FieldsSpec

type FieldsSpec struct {
	Type        string `json:"type,omitempty"`
	IgnoreAbove int    `json:"ignore_above,omitempty"`
}

type FileSystemSettings added in v0.11.2

type FileSystemSettings struct {
	Location string `json:"location"`
	Readonly bool   `json:"readonly"`
}

type ForceMergeOperation

type ForceMergeOperation struct {
	MaxNumSegments int `json:"max_num_segments"`
}

type GetIndexTemplateObject

type GetIndexTemplateObject struct {
	Name     string            `json:"name,omitempty"`
	Template IndexTemplateSpec `json:"index_template,omitempty"`
}

type GetIndexTemplateResponse

type GetIndexTemplateResponse struct {
	IndexTemplates []GetIndexTemplateObject `json:"index_templates,omitempty"`
}

type ISMGetResponse

type ISMGetResponse struct {
	ID          string        `json:"_id"`
	Version     int           `json:"_version"`
	SeqNo       int           `json:"_seq_no"`
	PrimaryTerm int           `json:"_primary_term"`
	Policy      ISMPolicySpec `json:"policy,omitempty"`
}

type ISMPolicyIDSpec

type ISMPolicyIDSpec struct {
	PolicyID   string `json:"policy_id,omitempty"`
	MarshallID bool   `json:"-"`
}

type ISMPolicySpec

type ISMPolicySpec struct {
	*ISMPolicyIDSpec  `json:",inline,omitempty"`
	Description       string            `json:"description"`
	ISMTemplate       []ISMTemplateSpec `json:"ism_template,omitempty"`
	ErrorNotification *NotificationSpec `json:"error_notification"`
	DefaultState      string            `json:"default_state"`
	States            []StateSpec       `json:"states"`
}

func (ISMPolicySpec) MarshalJSON

func (p ISMPolicySpec) MarshalJSON() ([]byte, error)

type ISMTemplateSpec

type ISMTemplateSpec struct {
	IndexPatterns []string `json:"index_patterns"`
	Priority      int      `json:"priority,omitempty"`
}

type IndexPermissionSpec

type IndexPermissionSpec struct {
	IndexPatterns         []string `json:"index_patterns,omitempty"`
	DocumentLevelSecurity string   `json:"dls,omitempty"`
	FieldLevelSecurity    []string `json:"fls,omitempty"`
	AllowedActions        []string `json:"allowed_actions,omitempty"`
}

type IndexPriorityOperation

type IndexPriorityOperation struct {
	Priority int `json:"priority"`
}

type IndexTemplateSpec

type IndexTemplateSpec struct {
	TemplateName  string       `json:"-"`
	IndexPatterns []string     `json:"index_patterns,omitempty"`
	Template      TemplateSpec `json:"template,omitempty"`
	Priority      int          `json:"priority,omitempty"`
}

type IngestPipeline

type IngestPipeline struct {
	Description string      `json:"description,omitempty"`
	Processors  []Processor `json:"processors,omitempty"`
}

type ListAlertResponse added in v0.11.0

type ListAlertResponse struct {
	Alerts      []Alert `json:"alerts"`
	TotalAlerts int     `json:"totalAlerts"`
}

type ListChannelResponse added in v0.11.0

type ListChannelResponse struct {
	StartIndex       int       `json:"start_index"`
	TotalHits        int       `json:"total_hits"`
	TotalHitRelation string    `json:"total_hit_relation"`
	ChannelList      []Channel `json:"config_list"`
}

type MessageTemplate added in v0.11.0

type MessageTemplate struct {
	Source string `json:"source"`
	Lang   string `json:"lang"`
}

type MetadataUpdate added in v0.9.1

type MetadataUpdate struct {
	Document         ClusterMetadataDocUpdate `json:"doc,omitempty"`
	DocumentAsUpsert *bool                    `json:"doc_as_upsert,omitempty"`
}

type Monitor added in v0.11.0

type Monitor struct {
	Name        string        `json:"name"`
	Type        string        `json:"type"`
	MonitorType string        `json:"monitor_type"`
	Enabled     bool          `json:"enabled"`
	Schedule    Schedule      `json:"schedule"`
	Inputs      []SearchInput `json:"inputs"`
	Triggers    []Trigger     `json:"triggers"`
}

type MonitorSpec added in v0.11.0

type MonitorSpec struct {
	Id          string  `json:"_id"`
	Version     int     `json:"_version"`
	SeqNo       int     `json:"_seq_no"`
	PrimaryTerm int     `json:"_primary_term"`
	Monitor     Monitor `json:"monitor"`
}

type NotificationSpec

type NotificationSpec struct {
	Destination     DestinationSpec `json:"destination"`
	MessageTemplate map[string]string
}

type OldISMGetResponse

type OldISMGetResponse struct {
	ID          string           `json:"_id"`
	Version     int              `json:"_version"`
	SeqNo       int              `json:"_seq_no"`
	PrimaryTerm int              `json:"_primary_term"`
	Policy      OldISMPolicySpec `json:"policy,omitempty"`
}

type OldISMPolicySpec

type OldISMPolicySpec struct {
	*ISMPolicyIDSpec  `json:",inline,omitempty"`
	Description       string            `json:"description"`
	ISMTemplate       *ISMTemplateSpec  `json:"ism_template,omitempty"`
	ErrorNotification *NotificationSpec `json:"error_notification"`
	DefaultState      string            `json:"default_state"`
	States            []StateSpec       `json:"states"`
}

func (OldISMPolicySpec) MarshalJSON

func (p OldISMPolicySpec) MarshalJSON() ([]byte, error)

type OpenOperation

type OpenOperation struct {
}

type OpniProcessorConfig

type OpniProcessorConfig struct {
}

type Processor

type Processor struct {
	OpniLoggingProcessor *OpniProcessorConfig `json:"opni-logging-processor,omitempty"`
	OpniPreProcessor     *OpniProcessorConfig `json:"opnipre,omitempty"`
}

type PropertySettings

type PropertySettings struct {
	Type        string                      `json:"type,omitempty"`
	Format      string                      `json:"format,omitempty"`
	Enabled     *bool                       `json:"enabled,omitempty"`
	Fields      map[string]FieldsSpec       `json:"fields,omitempty"`
	IgnoreAbove int                         `json:"ignore_above,omitempty"`
	Properties  map[string]PropertySettings `json:"properties,omitempty"`
}

type Query added in v0.11.0

type Query struct {
	Size         int             `json:"size"`
	Aggregations json.RawMessage `json:"aggregations"`
	Query        json.RawMessage `json:"query"`
}

type Range added in v0.11.0

type Range struct {
	GTE    string `json:"gte"`
	LTE    string `json:"lte"`
	Format string `json:"format"`
}

type ReadOnlyOperation

type ReadOnlyOperation struct {
}

type ReadWriteOperation

type ReadWriteOperation struct {
}

type ReindexDestSpec

type ReindexDestSpec struct {
	Index string `json:"index,omitempty"`
}

type ReindexSourceSpec

type ReindexSourceSpec struct {
	Index []string `json:"index,omitempty"`
}

type ReindexSpec

type ReindexSpec struct {
	Source      ReindexSourceSpec `json:"source"`
	Destination ReindexDestSpec   `json:"dest"`
}

type ReplicaCountOperation

type ReplicaCountOperation struct {
	NumberOfReplicas int `json:"number_of_replicas"`
}

type RepositoryRequest added in v0.11.2

type RepositoryRequest struct {
	Type     RepositoryType     `json:"type"`
	Settings RepositorySettings `json:"settings"`
}

type RepositorySettings added in v0.11.2

type RepositorySettings struct {
	*S3Settings         `json:",inline,omitempty"`
	*FileSystemSettings `json:",inline,omitempty"`
}

type RepositoryType added in v0.11.2

type RepositoryType string
const (
	RepositoryTypeS3         RepositoryType = "s3"
	RepositoryTypeFileSystem RepositoryType = "fs"
)

type RetrySpec

type RetrySpec struct {
	Count   int    `json:"count"`
	Backoff string `json:"backoff,omitempty"`
	Delay   string `json:"delay,omitempty"`
}

type RoleMappingReponse

type RoleMappingReponse map[string]RoleMappingSpec

type RoleMappingSpec

type RoleMappingSpec struct {
	BackendRoles []string `json:"backend_roles,omitempty"`
	Hosts        []string `json:"hosts,omitempty"`
	Users        []string `json:"users,omitempty"`
}

type RoleSpec

type RoleSpec struct {
	RoleName           string                  `json:"-"`
	ClusterPermissions []string                `json:"cluster_permissions,omitempty"`
	IndexPermissions   []IndexPermissionSpec   `json:"index_permissions,omitempty"`
	TenantPermissions  []TenantPermissionsSpec `json:"tenant_permissions,omitempty"`
}

type RolloverOperation

type RolloverOperation struct {
	MinSize     string `json:"min_size,omitempty"`
	MinDocCount int    `json:"min_doc_count,omitempty"`
	MinIndexAge string `json:"min_index_age,omitempty"`
}

type S3Settings added in v0.11.2

type S3Settings struct {
	Bucket    string `json:"bucket"`
	Path      string `json:"base_path"`
	ReadOnly  bool   `json:"readonly"`
	ChunkSize string `json:"chunk_size,omitempty"`
}

type Schedule added in v0.11.0

type Schedule struct {
	Period struct {
		Unit     string `json:"unit"`
		Interval int    `json:"interval"`
	} `json:"period"`
}

type SearchInput added in v0.11.0

type SearchInput struct {
	Search struct {
		Indices []string `json:"indices"`
		Query   Query    `json:"query"`
	} `json:"search"`
}

type SlackConfig added in v0.11.0

type SlackConfig struct {
	URL string `json:"url"`
}

type SlackSpec

type SlackSpec struct {
	URL string `json:"url"`
}

type SnapshotConfig added in v0.11.2

type SnapshotConfig struct {
	SnapshotRequest `json:",inline"`
	Repository      string            `json:"repository"`
	DateFormat      string            `json:"date_format,omitempty"`
	Timezone        string            `json:"timezone,omitempty"`
	Metadata        map[string]string `json:"metadata,omitempty"`
}

type SnapshotCreation added in v0.11.2

type SnapshotCreation struct {
	// Cron string
	Schedule  *SnapshotSchedule `json:"schedule,omitempty"`
	TimeLimit string            `json:"time_limit,omitempty"`
}

type SnapshotCronSchedule added in v0.11.2

type SnapshotCronSchedule struct {
	Expression string `json:"expression,omitempty"`
	Timezone   string `json:"timezone,omitempty"`
}

type SnapshotDeleteCondition added in v0.11.2

type SnapshotDeleteCondition struct {
	MaxCount *int32 `json:"max_count,omitempty"`
	MaxAge   string `json:"max_age,omitempty"`
	MinCount *int32 `json:"min_count,omitempty"`
}

type SnapshotDeletion added in v0.11.2

type SnapshotDeletion struct {
	// Cron string
	Schedule  *SnapshotSchedule       `json:"schedule,omitempty"`
	TimeLimit string                  `json:"time_limit,omitempty"`
	Condition SnapshotDeleteCondition `json:"condition,omitempty"`
}

type SnapshotManagementRequest added in v0.11.2

type SnapshotManagementRequest struct {
	Description    string            `json:"description,omitempty"`
	Enabled        *bool             `json:"enabled,omitempty"`
	SnapshotConfig SnapshotConfig    `json:"snapshot_config"`
	Creation       SnapshotCreation  `json:"creation"`
	Deletion       *SnapshotDeletion `json:"deletion,omitempty"`
}

type SnapshotManagementResponse added in v0.11.2

type SnapshotManagementResponse struct {
	Version     int                       `json:"_version"`
	SeqNo       int                       `json:"_seq_no"`
	PrimaryTerm int                       `json:"_primary_term"`
	Policy      SnapshotManagementRequest `json:"sm_policy"`
}

type SnapshotOperation

type SnapshotOperation struct {
	Repository   string `json:"repository"`
	SnapshotName string `json:"snapshot"`
}

type SnapshotPolicyExecuitonInfo added in v0.11.2

type SnapshotPolicyExecuitonInfo struct {
	Message string `json:"message,omitempty"`
	Cause   string `json:"cause,omitempty"`
}

type SnapshotPolicyExecution added in v0.11.2

type SnapshotPolicyExecution struct {
	Status    SnapshotPolicyExecutionStatus `json:"status,omitempty"`
	StartTime Time                          `json:"start_time,omitempty"`
	EndTime   Time                          `json:"end_time,omitempty"`
	Info      SnapshotPolicyExecuitonInfo   `json:"info,omitempty"`
}

type SnapshotPolicyExecutionStatus added in v0.11.2

type SnapshotPolicyExecutionStatus string
const (
	SnapshotPolicyExecutionStatusInProgress SnapshotPolicyExecutionStatus = "IN_PROGRESS"
	SnapshotPolicyExecutionStatusSuccess    SnapshotPolicyExecutionStatus = "SUCCESS"
	SnapshotPolicyExecutionStatusRetrying   SnapshotPolicyExecutionStatus = "RETRYING"
	SnapshotPolicyExecutionStatusFailed     SnapshotPolicyExecutionStatus = "FAILED"
	SnapshotPolicyExecutionStatusTimedOut   SnapshotPolicyExecutionStatus = "TIME_LIMIT_EXCEEDED"
)

type SnapshotPolicyExplain added in v0.11.2

type SnapshotPolicyExplain struct {
	Policies []SnapshotPolicyExplainResponse `json:"policies"`
}

type SnapshotPolicyExplainResponse added in v0.11.2

type SnapshotPolicyExplainResponse struct {
	Creation          SnapshotPolicyStateMachine `json:"creation,omitempty"`
	Deletion          SnapshotPolicyStateMachine `json:"deletion,omitempty"`
	PolicySeqNo       *int                       `json:"policy_seq_no,omitempty"`
	PolicyPrimaryTerm *int                       `json:"policy_primary_term,omitempty"`
	Enabled           *bool                      `json:"enabled,omitempty"`
}

type SnapshotPolicyRetry added in v0.11.2

type SnapshotPolicyRetry struct {
	Count *int `json:"count,omitempty"`
}

type SnapshotPolicyStateMachine added in v0.11.2

type SnapshotPolicyStateMachine struct {
	CurrentState    string                  `json:"current_state,omitempty"`
	Trigger         SnapshotPolicyTrigger   `json:"trigger,omitempty"`
	LatestExecution SnapshotPolicyExecution `json:"latest_execution,omitempty"`
	Retry           SnapshotPolicyRetry     `json:"retry,omitempty"`
}

type SnapshotPolicyTrigger added in v0.11.2

type SnapshotPolicyTrigger struct {
	Time Time `json:"time,omitempty"`
}

type SnapshotRequest added in v0.11.2

type SnapshotRequest struct {
	Indices            string `json:"indices,omitempty"`
	IgnoreUnavailable  bool   `json:"ignore_unavailable,omitempty"`
	IncludeGlobalState *bool  `json:"include_global_state,omitempty"`
	Partial            bool   `json:"partial,omitempty"`
}

type SnapshotResponse added in v0.11.2

type SnapshotResponse struct {
	Snapshots []SnapshotStatus `json:"snapshots"`
}

type SnapshotSchedule added in v0.11.2

type SnapshotSchedule struct {
	CronSchedule *SnapshotCronSchedule `json:"cron,omitempty"`
}

type SnapshotShardStatus added in v0.11.2

type SnapshotShardStatus struct {
	Total      int `json:"total"`
	Failed     int `json:"failed"`
	Successful int `json:"successful"`
}

type SnapshotState added in v0.11.2

type SnapshotState string
const (
	SnapshotStateInProgress SnapshotState = "IN_PROGRESS"
	SnapshotStateSuccess    SnapshotState = "SUCCESS"
	SnapshotStateFailed     SnapshotState = "FAILED"
	SnapshotStatePartial    SnapshotState = "PARTIAL"
)

type SnapshotStatus added in v0.11.2

type SnapshotStatus struct {
	UUID     string              `json:"uuid"`
	Indices  []string            `json:"indices"`
	State    SnapshotState       `json:"state"`
	Duration int                 `json:"duration_in_millis"`
	Failures []string            `json:"failures"`
	Shards   SnapshotShardStatus `json:"shards"`
}

type StateSpec

type StateSpec struct {
	Name        string           `json:"name"`
	Actions     []ActionSpec     `json:"actions,omitempty"`
	Transitions []TransitionSpec `json:"transitions,omitempty"`
}

func (*StateSpec) UnmarshalJSON

func (s *StateSpec) UnmarshalJSON(data []byte) error

type SubjectTemplate added in v0.11.0

type SubjectTemplate struct {
	Source string `json:"source"`
	Lang   string `json:"lang"`
}

type TemplateMappingsSpec

type TemplateMappingsSpec struct {
	DateDetection    *bool                            `json:"date_detection,omitempty"`
	DynamicTemplates []map[string]DynamicTemplateSpec `json:"dynamic_templates,omitempty"`
	Properties       map[string]PropertySettings      `json:"properties,omitempty"`
}

type TemplateSettingsSpec

type TemplateSettingsSpec struct {
	NumberOfShards   int    `json:"number_of_shards,omitempty"`
	NumberOfReplicas int    `json:"number_of_replicas,omitempty"`
	ISMPolicyID      string `json:"opendistro.index_state_management.policy_id,omitempty"`
	RolloverAlias    string `json:"opendistro.index_state_management.rollover_alias,omitempty"`
	DefaultPipeline  string `json:"default_pipeline,omitempty"`
}

func (*TemplateSettingsSpec) UnmarshalJSON

func (t *TemplateSettingsSpec) UnmarshalJSON(data []byte) error

type TemplateSpec

type TemplateSpec struct {
	Settings TemplateSettingsSpec `json:"settings,omitempty"`
	Mappings TemplateMappingsSpec `json:"mappings,omitempty"`
}

type TenantPermissionsSpec

type TenantPermissionsSpec struct {
	TenantPatterns []string `json:"tenant_patterns,omitempty"`
	AllowedActions []string `json:"allowed_actions,omitempty"`
}

type Time added in v0.11.2

type Time struct {
	time.Time
}

func (Time) MarshalJSON added in v0.11.2

func (t Time) MarshalJSON() ([]byte, error)

func (*Time) UnmarshalJSON added in v0.11.2

func (t *Time) UnmarshalJSON(b []byte) error

type TransitionSpec

type TransitionSpec struct {
	StateName  string         `json:"state_name"`
	Conditions *ConditionSpec `json:"conditions,omitempty"`
}

type Trigger added in v0.11.0

type Trigger struct {
	QueryLevelTrigger struct {
		ID        string    `json:"id"`
		Name      string    `json:"name"`
		Severity  string    `json:"severity"`
		Condition Condition `json:"condition"`
		Actions   []Action  `json:"actions"`
	} `json:"query_level_trigger"`
}

type UIMetadata added in v0.11.0

type UIMetadata struct {
	Schedule struct {
		Timezone  interface{} `json:"timezone"`
		Frequency string      `json:"frequency"`
		Period    Schedule    `json:"period"`
		Daily     int         `json:"daily"`
		Weekly    struct {
			Tue  bool `json:"tue"`
			Wed  bool `json:"wed"`
			Thur bool `json:"thur"`
			Sat  bool `json:"sat"`
			Fri  bool `json:"fri"`
			Mon  bool `json:"mon"`
			Sun  bool `json:"sun"`
		} `json:"weekly"`
		Monthly struct {
			Type string `json:"type"`
			Day  int    `json:"day"`
		} `json:"monthly"`
		CronExpression string `json:"cronExpression"`
	} `json:"schedule"`
	MonitorType string `json:"monitor_type"`
	Search      struct {
		SearchType       string   `json:"searchType"`
		TimeField        string   `json:"timeField"`
		Aggregations     []string `json:"aggregations"`
		GroupBy          []string `json:"groupBy"`
		BucketValue      int      `json:"bucketValue"`
		BucketUnitOfTime string   `json:"bucketUnitOfTime"`
		Where            struct {
			FieldName       []string `json:"fieldName"`
			FieldRangeEnd   int      `json:"fieldRangeEnd"`
			FieldRangeStart int      `json:"fieldRangeStart"`
			FieldValue      string   `json:"fieldValue"`
			Operator        string   `json:"operator"`
		} `json:"where"`
	} `json:"search"`
}

type UpdateAliasRequest

type UpdateAliasRequest struct {
	Actions []AliasActionSpec `json:"actions,omitempty"`
}

type UpsertDashboardsDoc

type UpsertDashboardsDoc struct {
	Document         DashboardsVersionDoc `json:"doc,omitempty"`
	DocumentAsUpsert *bool                `json:"doc_as_upsert,omitempty"`
}

type User added in v0.11.0

type User struct {
	Name                 string   `json:"name"`
	BackendRoles         []string `json:"backend_roles"`
	Roles                []string `json:"roles"`
	CustomAttributeNames []string `json:"custom_attribute_names"`
	UserRequestedTenant  string   `json:"user_requested_tenant"`
}

type UserSpec

type UserSpec struct {
	UserName                string            `json:"-"`
	Password                string            `json:"password,omitempty"`
	Hash                    string            `json:"hash,omitempty"`
	OpendistroSecurityRoles []string          `json:"opendistro_security_roles,omitempty"`
	BackendRoles            []string          `json:"backend_roles,omitempty"`
	Attributes              map[string]string `json:"attributes,omitempty"`
}

type WebhookConfig added in v0.11.0

type WebhookConfig struct {
	URL          string            `json:"url"`
	HeaderParams map[string]string `json:"header_params"`
	Method       string            `json:"method"`
}

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL