model

package
v0.6.1 Latest Latest
Warning

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

Go to latest
Published: Apr 17, 2024 License: MIT Imports: 2 Imported by: 1

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type AllowedDataType added in v0.5.0

type AllowedDataType struct {
	NullDefault any `json:"nullDefault,omitempty"`
}

type BodyPart

type BodyPart struct {
	ContentDisposition   ContentDisposition               `json:"contentDisposition"`
	Entity               map[string]interface{}           `json:"entity"`
	Headers              map[string][]string              `json:"headers"`
	MediaType            MediaType                        `json:"mediaType"`
	MessageBodyWorkers   map[string]interface{}           `json:"messageBodyWorkers"`
	Parent               string                           `json:"parent"`
	Providers            map[string]interface{}           `json:"providers"`
	ParameterizedHeaders map[string][]ParameterizedHeader `json:"parameterizedHeaders"`
}

BodyPart represents the structure for body parts within the JSON.

type BrokerInstances added in v0.5.0

type BrokerInstances struct {
	TableType string   `json:"tableType,omitempty"`
	Instances []string `json:"instances,omitempty"`
}

type ClusterConfig added in v0.1.5

type ClusterConfig struct {
	AllowParticipantAutoJoin            string `json:"allowParticipantAutoJoin"`
	EnableCaseInsensitive               string `json:"enable.case.insensitive"`
	DefaultHyperlogLogLog2m             string `json:"default.hyperloglog.log2m"`
	PinotBrokerEnableQueryLimitOverride string `json:"pinot.broker.enable.query.limit.override"`
}

type ColumnPartitionMapConfig added in v0.1.5

type ColumnPartitionMapConfig struct {
	FunctionName  string `json:"functionName"`
	NumPartitions int    `json:"numPartitions"`
}

type ColumnToIndex added in v0.5.0

type ColumnToIndex struct {
	VectorIndex     int `json:"vector_index,omitempty"`
	NullValueVector int `json:"nullvalue_vector,omitempty"`
	H3Index         int `json:"h3_index,omitempty"`
	Dictionary      int `json:"dictionary,omitempty"`
	JsonIndex       int `json:"json_index,omitempty"`
	RangeIndex      int `json:"range_index,omitempty"`
	ForwardIndex    int `json:"forward_index,omitempty"`
	BloomFilter     int `json:"bloom_filter,omitempty"`
	InvertedIndex   int `json:"inverted_index,omitempty"`
	TextIndex       int `json:"text_index,omitempty"`
	FSTIndex        int `json:"fst_index,omitempty"`
}

type ContentDisposition

type ContentDisposition struct {
	Type             string            `json:"type"`
	Parameters       map[string]string `json:"parameters"`
	FileName         string            `json:"fileName"`
	CreationDate     time.Time         `json:"creationDate"`
	ModificationDate time.Time         `json:"modificationDate"`
	ReadDate         time.Time         `json:"readDate"`
	Size             int               `json:"size"`
}

ContentDisposition represents the structure for content disposition.

type CreateSchemaResponse added in v0.2.0

type CreateSchemaResponse struct {
	UnrecognizedProperties map[string]string `json:"unrecognizedProperties,omitempty"`
	Status                 string            `json:"status"`
}

type CreateTablesResponse

type CreateTablesResponse struct {
	UnrecognizedProperties map[string]any `json:"unrecognizedProperties"`
	Status                 string         `json:"status"`
}

type DataType added in v0.5.0

type DataType struct {
	StoredType string `json:"storedType,omitempty"`
	Size       int    `json:"size,omitempty"`
	Sortable   bool   `json:"sortable,omitempty"`
	Numeric    bool   `json:"numeric,omitempty"`
}

type DedupConfig added in v0.1.5

type DedupConfig struct {
	DedupEnabled bool   `json:"dedupEnabled"`
	HashFunction string `json:"hashFunction"`
}

type Field

type Field struct {
	ContentDisposition         ContentDisposition               `json:"contentDisposition"`
	Entity                     map[string]interface{}           `json:"entity"`
	Headers                    map[string][]string              `json:"headers"`
	MediaType                  MediaType                        `json:"mediaType"`
	MessageBodyWorkers         map[string]interface{}           `json:"messageBodyWorkers"`
	Parent                     Parent                           `json:"parent"`
	Providers                  map[string]interface{}           `json:"providers"`
	Name                       string                           `json:"name"`
	Value                      string                           `json:"value"`
	Simple                     bool                             `json:"simple"`
	FormDataContentDisposition ContentDisposition               `json:"formDataContentDisposition"`
	ParameterizedHeaders       map[string][]ParameterizedHeader `json:"parameterizedHeaders"`
}

Field represents a more detailed structure within "fields" which can contain nested structures similar to BodyPart.

type FieldConfig

type FieldConfig struct {
	Name            string           `json:"name"`
	EncodingType    string           `json:"encodingType"`
	IndexType       string           `json:"indexType"`
	IndexTypes      []string         `json:"indexTypes"`
	TimestampConfig *TimestampConfig `json:"timestampConfig,omitempty"`
	Indexes         *FieldIndexes    `json:"indexes,omitempty"`
}

type FieldIndexes

type FieldIndexes struct {
	Inverted *FiendIndexInverted `json:"inverted,omitempty"`
}

type FieldSpec

type FieldSpec struct {
	Name             string `json:"name"`
	DataType         string `json:"dataType"`
	Format           string `json:"format,omitempty"`
	Granularity      string `json:"granularity,omitempty"`
	NotNull          *bool  `json:"notNull,omitempty"`
	SingleValueField *bool  `json:"singleValueField,omitempty"`
}

type FieldType added in v0.5.0

type FieldType struct {
	AllowedDataTypes map[string]AllowedDataType `json:"allowedDataTypes,omitempty"`
}

type FiendIndexInverted

type FiendIndexInverted struct {
	Enabled string `json:"enabled"`
}

type FilterConfig added in v0.4.2

type FilterConfig struct {
	FilterFunction string `json:"filterFunction"`
}

type GetClusterConfigResponse added in v0.1.5

type GetClusterConfigResponse struct {
	AllowParticipantAutoJoin            string `json:"allowParticipantAutoJoin"`
	EnableCaseInsensitive               string `json:"enable.case.insensitive"`
	DefaultHyperlogLogLog2m             string `json:"default.hyperloglog.log2m"`
	PinotBrokerEnableQueryLimitOverride string `json:"pinot.broker.enable.query.limit.override"`
}

type GetClusterResponse added in v0.1.5

type GetClusterResponse struct {
	ClusterName string `json:"clusterName"`
}

type GetInstanceResponse added in v0.1.5

type GetInstanceResponse struct {
	InstanceName       string             `json:"instanceName"`
	Hostname           string             `json:"hostname"`
	Enabled            bool               `json:"enabled"`
	Port               string             `json:"port"`
	Tags               []string           `json:"tags"`
	Pools              []string           `json:"pools"`
	GRPCPort           int                `json:"grpcPort"`
	AdminPort          int                `json:"adminPort"`
	QueryServicePort   int                `json:"queryServicePort"`
	QueryMailboxPort   int                `json:"queryMailboxPort"`
	SystemResourceInfo SystemResourceInfo `json:"systemResourceInfo,omitempty"`
}

type GetInstancesResponse added in v0.1.5

type GetInstancesResponse struct {
	Instances []string `json:"instances"`
}

type GetLiveBrokersResponse added in v0.5.0

type GetLiveBrokersResponse map[string][]LiveBrokerInstance

type GetSchemaFieldSpecsResponse added in v0.5.0

type GetSchemaFieldSpecsResponse struct {
	FieldTypes map[string]FieldType `json:"fieldTypes,omitempty"`
	DataTypes  map[string]DataType  `json:"dataTypes,omitempty"`
}

type GetSchemaResponse

type GetSchemaResponse []string

func (*GetSchemaResponse) ForEachSchema

func (g *GetSchemaResponse) ForEachSchema(apply func(schemaName string))

type GetSegmentCRCResponse added in v0.6.0

type GetSegmentCRCResponse map[string]string

type GetSegmentMetadataResponse

type GetSegmentMetadataResponse map[string]SegmentMetadata

type GetSegmentTiersResponse added in v0.6.0

type GetSegmentTiersResponse struct {
	SegmentTiers map[string]map[string]string `json:"segmentTiers"`
	TableName    string                       `json:"tableName"`
}

type GetSegmentZKMetadataResponse added in v0.6.0

type GetSegmentZKMetadataResponse map[string]ZkSegmentMetadata

type GetSegmentsResponse

type GetSegmentsResponse []SegmentDetail

Root struct for the JSON array

type GetTableExternalViewResponse added in v0.5.0

type GetTableExternalViewResponse struct {
	Offline  map[string]map[string]string `json:"offline,omitempty"`
	Realtime map[string]map[string]string `json:"realtime,omitempty"`
}

type GetTableIdealStateResponse added in v0.5.0

type GetTableIdealStateResponse struct {
	Offline  map[string]map[string]string `json:"OFFLINE,omitempty"`
	Realtime map[string]map[string]string `json:"REALTIME,omitempty"`
}

type GetTableIndexesResponse added in v0.5.0

type GetTableIndexesResponse struct {
	TotalOnlineSegments  int                      `json:"totalOnlineSegments,omitempty"`
	ColumnToIndexesCount map[string]ColumnToIndex `json:"columnToIndexesCount,omitempty"`
}

type GetTableInstancesResponse added in v0.5.0

type GetTableInstancesResponse struct {
	TableName string            `json:"tableName,omitempty"`
	Brokers   []BrokerInstances `json:"brokers,omitempty"`
	Servers   []ServerInstances `json:"servers,omitempty"`
}

type GetTableLiveBrokersResponse added in v0.5.0

type GetTableLiveBrokersResponse struct {
}

type GetTableMetadataResponse added in v0.5.0

type GetTableMetadataResponse struct {
	TableName                                 string           `json:"tableName"`
	DiskSizeInBytes                           int64            `json:"diskSizeInBytes"`
	NumSegments                               int              `json:"numSegments"`
	NumRows                                   int64            `json:"numRows"`
	ColumnLengthMap                           map[string]int   `json:"columnLengthMap"`
	ColumnCardinalityMap                      map[string]int   `json:"columnCardinalityMap"`
	MaxNumMultiValuesMap                      map[string]int   `json:"maxNumMultiValuesMap"`
	ColumnIndexSizeMap                        map[string]int64 `json:"columnIndexSizeMap"`
	UpsertPartitionToServerPrimaryKeyCountMap map[string]int64 `json:"upsertPartitionToServerPrimaryKeyCountMap"`
}

type GetTableResponse

type GetTableResponse struct {
	OFFLINE  Table `json:"OFFLINE"`
	REALTIME Table `json:"REALTIME"`
}

type GetTableSizeResponse added in v0.5.0

type GetTableSizeResponse struct {
	TableName                     string        `json:"tableName"`
	ReportedSizeInBytes           int64         `json:"reportedSizeInBytes"`
	EstimatedSizeInBytes          int64         `json:"estimatedSizeInBytes"`
	ReportedSizePerReplicaInBytes int64         `json:"reportedSizePerReplicaInBytes"`
	OfflineSegments               TableSegments `json:"offlineSegments"`
	RealtimeSegments              TableSegments `json:"realtimeSegments"`
}

type GetTableStateResponse added in v0.5.0

type GetTableStateResponse struct {
	State string `json:"state"`
}

type GetTableStatsResponse added in v0.5.0

type GetTableStatsResponse map[string]TableStats

type GetTablesResponse

type GetTablesResponse struct {
	Tables []string `json:"tables"`
}

type GetTenantMetadataResponse added in v0.1.5

type GetTenantMetadataResponse struct {
	ServerInstances         []string `json:"ServerInstances"`
	BrokerInstances         []string `json:"BrokerInstances"`
	OfflineServerInstances  []string `json:"OfflineServerInstances"`
	RealtimeServerInstances []string `json:"RealtimeServerInstances"`
	TenantName              string   `json:"TenantName"`
}

type GetTenantResponse added in v0.1.5

type GetTenantResponse struct {
	ServerInstances []string `json:"ServerInstances"`
	BrokerInstances []string `json:"BrokerInstances"`
	TenantName      string   `json:"TenantName"`
}

GetTenantResponse Get tenant response

type GetTenantsResponse

type GetTenantsResponse struct {
	ServerTenants []string `json:"SERVER_TENANTS"`
	BrokerTenants []string `json:"BROKER_TENANTS"`
}

type GetUserResponse

type GetUserResponse struct {
	User map[string]User
}

GetUserResponse is a struct that represents the response from the GetUser method

type GetUsersResponse

type GetUsersResponse struct {
	Users map[string]User `json:"users"`
}

type Instance added in v0.1.5

type Instance struct {
	Host string `json:"host"`
	Port int    `json:"port"`
	Type string `json:"type"` // Can be CONTROLLER, BROKER, SERVER, MINION
}

type LiveBrokerInstance added in v0.5.0

type LiveBrokerInstance struct {
	InstanceName string `json:"instanceName"`
	Port         int    `json:"port"`
	Host         string `json:"host"`
}

type MediaType

type MediaType struct {
	Type            string            `json:"type"`
	Subtype         string            `json:"subtype"`
	Parameters      map[string]string `json:"parameters"`
	WildcardType    bool              `json:"wildcardType"`
	WildcardSubtype bool              `json:"wildcardSubtype"`
}

MediaType represents the structure for media type.

type ParameterizedHeader

type ParameterizedHeader struct {
	Value      string            `json:"value"`
	Parameters map[string]string `json:"parameters"`
}

ParameterizedHeader represents the structure for parameterized headers.

type Parent

type Parent struct {
	ContentDisposition   ContentDisposition               `json:"contentDisposition"`
	Entity               map[string]interface{}           `json:"entity"`
	Headers              map[string][]string              `json:"headers"`
	MediaType            MediaType                        `json:"mediaType"`
	MessageBodyWorkers   map[string]interface{}           `json:"messageBodyWorkers"`
	Parent               string                           `json:"parent"`
	Providers            map[string]interface{}           `json:"providers"`
	BodyParts            []BodyPart                       `json:"bodyParts"`
	ParameterizedHeaders map[string][]ParameterizedHeader `json:"parameterizedHeaders"`
}

Parent represents the structure for parent, similar to Root but includes Parent and BodyParts fields.

type PlainTextAPIResponse added in v0.5.0

type PlainTextAPIResponse struct {
	Response string
}

type QueryConfig added in v0.1.5

type QueryConfig struct {
	TimeoutMs              string            `json:"timeoutMs"`
	DisableGroovy          bool              `json:"disableGroovy"`
	UseApproximateFunction bool              `json:"useApproximateFunction"`
	ExpressionOverrideMap  map[string]string `json:"expressionOverrideMap"`
	MaxQueryResponseBytes  string            `json:"maxQueryResponseBytes"`
	MaxServerResponseBytes string            `json:"maxServerResponseBytes"`
}

type QuotaConfig added in v0.1.5

type QuotaConfig struct {
	Storage             string `json:"storage"`
	MaxQueriesPerSecond int    `json:"maxQueriesPerSecond"`
}

type RoutingConfig added in v0.1.5

type RoutingConfig struct {
	SegmentPrunerTypes   []string `json:"segmentPrunerTypes"`
	InstanceSelectorType string   `json:"instanceSelectorType"`
}

type Schema

type Schema struct {
	SchemaName          string      `json:"schemaName"`
	DimensionFieldSpecs []FieldSpec `json:"dimensionFieldSpecs"`
	MetricFieldSpecs    []FieldSpec `json:"metricFieldSpecs,omitempty"`
	DateTimeFieldSpecs  []FieldSpec `json:"dateTimeFieldSpecs,omitempty"`
	PrimaryKeyColumns   []string    `json:"primaryKeyColumns,omitempty"`
}

func (*Schema) AsBytes

func (schema *Schema) AsBytes() ([]byte, error)

func (*Schema) String

func (schema *Schema) String() string

type Segment

type Segment struct {
	ContentDisposition   ContentDisposition               `json:"contentDisposition"`
	Entity               map[string]interface{}           `json:"entity"`
	Headers              map[string][]string              `json:"headers"`
	MediaType            MediaType                        `json:"mediaType"`
	MessageBodyWorkers   map[string]interface{}           `json:"messageBodyWorkers"`
	Parent               Parent                           `json:"parent"`
	Providers            map[string]interface{}           `json:"providers"`
	BodyParts            []BodyPart                       `json:"bodyParts"`
	Fields               map[string][]Field               `json:"fields"`
	ParameterizedHeaders map[string][]ParameterizedHeader `json:"parameterizedHeaders"`
}

type SegmentDetail

type SegmentDetail struct {
	Offline  []string `json:"OFFLINE,omitempty"`
	Realtime []string `json:"REALTIME,omitempty"`
}

Event represents the structure within each array element, accommodating both offline and realtime events.

type SegmentMetadata added in v0.6.0

type SegmentMetadata struct {
	SegmentName          string            `json:"segmentName"`
	SchemaName           string            `json:"schemaName"`
	CRC                  int64             `json:"crc"`
	CreationTimeMillis   int64             `json:"creationTimeMillis"`
	CreationTimeReadable string            `json:"creationTimeReadable"`
	TimeColumn           string            `json:"timeColumn"`
	TimeUnit             string            `json:"timeUnit"`
	TimeGranularitySec   int64             `json:"timeGranularitySec"`
	StartTimeMillis      int64             `json:"startTimeMillis"`
	StartTimeReadable    string            `json:"startTimeReadable"`
	EndTimeMillis        int64             `json:"endTimeMillis"`
	EndTimeReadable      string            `json:"endTimeReadable"`
	SegmentVersion       string            `json:"segmentVersion"`
	CreatorName          string            `json:"creatorName"`
	TotalDocs            int64             `json:"totalDocs"`
	Custom               map[string]string `json:"custom"`
	StartOffset          int64             `json:"startOffset"`
	EndOffset            int64             `json:"endOffset"`
	Columns              []string          `json:"columns"`
	Indexes              any               `json:"indexes"`
	StarTreeIndex        []StarTreeIndex   `json:"star-tree-index"`
}

type SegmentPartitionConfig added in v0.1.5

type SegmentPartitionConfig struct {
	ColumnPartitionMap map[string]ColumnPartitionMapConfig `json:"columnPartitionMap"`
}

type SegmentSizeDetail added in v0.5.0

type SegmentSizeDetail struct {
	ReportedSizeInBytes              int64                 `json:"reportedSizeInBytes"`
	EstimatedSizeInBytes             int64                 `json:"estimatedSizeInBytes"`
	MaxReportedSizePerReplicainBytes int64                 `json:"maxReportedSizePerReplicaInBytes"`
	ServerInfo                       map[string]ServerInfo `json:"serverInfo"`
}

type ServerInfo added in v0.5.0

type ServerInfo struct {
	SegmentName     string `json:"segmentName"`
	DiskSizeInBytes int64  `json:"diskSizeInBytes"`
}

type ServerInstances added in v0.5.0

type ServerInstances struct {
	TableType string   `json:"tableType,omitempty"`
	Instances []string `json:"instances,omitempty"`
}

type StarTreeIndex added in v0.6.0

type StarTreeIndex struct {
	DimensionColumns        []string `json:"dimension-columns"`
	MetricAggregations      []string `json:"metric-aggregations"`
	MaxLeafRecords          int64    `json:"max-leaf-records"`
	DimensionColumnsSkipped []string `json:"dimension-columns-skipped"`
}

type StarTreeIndexConfig

type StarTreeIndexConfig struct {
	DimensionsSplitOrder              []string `json:"dimensionsSplitOrder"`
	SkipStarNodeCreationForDimensions []string `json:"skipStarNodeCreationForDimensions"`
	FunctionColumnPairs               []string `json:"functionColumnPairs"`
	MaxLeafRecords                    int      `json:"maxLeafRecords"`
}

type StreamIngestionConfig added in v0.1.5

type StreamIngestionConfig struct {
	StreamConfigMaps []map[string]string `json:"streamConfigMaps"`
}

type SystemResourceInfo added in v0.1.5

type SystemResourceInfo struct {
	NumCores      string `json:"numCores"`
	TotalMemoryMB string `json:"totalMemoryMB"`
	MaxHeapSizeMB string `json:"maxHeapSizeMB"`
}

type Table

type Table struct {
	TableName        string                `json:"tableName"`
	TableType        string                `json:"tableType"`
	SegmentsConfig   TableSegmentsConfig   `json:"segmentsConfig"`
	Tenants          TableTenant           `json:"tenants"`
	TableIndexConfig TableIndexConfig      `json:"tableIndexConfig"`
	Metadata         *TableMetadata        `json:"metadata"`
	FieldConfigList  []FieldConfig         `json:"fieldConfigList,omitempty"`
	IngestionConfig  *TableIngestionConfig `json:"ingestionConfig,omitempty"`
	TierConfigs      []*TierConfig         `json:"tierConfigs,omitempty"`
	IsDimTable       bool                  `json:"isDimTable"`
	Query            *QueryConfig          `json:"query,omitempty"`
	Routing          *RoutingConfig        `json:"routing,omitempty"`
	Quota            *QuotaConfig          `json:"quota,omitempty"`
	UpsertConfig     *UpsertConfig         `json:"upsertConfig,omitempty"`
	DedupConfig      *DedupConfig          `json:"dedupConfig,omitempty"`
	Task             *Task                 `json:"task,omitempty"`
}

func (*Table) IsEmpty added in v0.2.0

func (t *Table) IsEmpty() bool

type TableIndexConfig

type TableIndexConfig struct {
	CreateInvertedIndexDuringSegmentGeneration bool                    `json:"createInvertedIndexDuringSegmentGeneration"`
	SortedColumn                               []string                `json:"sortedColumn,omitempty"`
	StarTreeIndexConfigs                       []*StarTreeIndexConfig  `json:"starTreeIndexConfigs,omitempty"`
	EnableDefaultStarTree                      bool                    `json:"enableDefaultStarTree,omitempty"`
	EnableDynamicStarTreeCreation              bool                    `json:"enableDynamicStarTreeCreation,omitempty"`
	SegmentPartitionConfig                     *SegmentPartitionConfig `json:"segmentPartitionConfig,omitempty"`
	LoadMode                                   string                  `json:"loadMode"`
	ColumnMinMaxValueGeneratorMode             string                  `json:"columnMinMaxValueGeneratorMode,omitempty"`
	NullHandlingEnabled                        bool                    `json:"nullHandlingEnabled"`
	AggregateMetrics                           bool                    `json:"aggregateMetrics,omitempty"`
	OptimizeDictionary                         bool                    `json:"optimizeDictionary"`
	OptimizeDictionaryForMetrics               bool                    `json:"optimizeDictionaryForMetrics"`
	NoDictionarySizeRatioThreshold             float64                 `json:"noDictionarySizeRatioThreshold"`
	SegmentNameGeneratorType                   string                  `json:"segmentNameGeneratorType"`
	InvertedIndexColumns                       []string                `json:"invertedIndexColumns,omitempty"`
	NoDictionaryColumns                        []string                `json:"noDictionaryColumns,omitempty"`
	RangeIndexColumns                          []string                `json:"rangeIndexColumns,omitempty"`
	OnHeapDictionaryColumns                    []string                `json:"onHeapDictionaryColumns,omitempty"`
	VarLengthDictionaryColumns                 []string                `json:"varLengthDictionaryColumns,omitempty"`
	BloomFilterColumns                         []string                `json:"bloomFilterColumns,omitempty"`
	RangeIndexVersion                          int                     `json:"rangeIndexVersion,omitempty"`
}

type TableIngestionConfig

type TableIngestionConfig struct {
	SegmentTimeValueCheck bool                   `json:"segmentTimeValueCheck,omitempty"`
	TransformConfigs      []TransformConfig      `json:"transformConfigs,omitempty"`
	FilterConfig          *FilterConfig          `json:"filterConfig,omitempty"`
	ContinueOnError       bool                   `json:"continueOnError,omitempty"`
	RowTimeValueCheck     bool                   `json:"rowTimeValueCheck,omitempty"`
	StreamIngestionConfig *StreamIngestionConfig `json:"streamIngestionConfig,omitempty"`
}

type TableMetadata

type TableMetadata struct {
	CustomConfigs map[string]string `json:"customConfigs"`
}

type TableSegments added in v0.5.0

type TableSegments struct {
	ReportedSizeInBytes           int64                        `json:"reportedSizeInBytes"`
	EstimatedSizeInBytes          int64                        `json:"estimatedSizeInBytes"`
	MissingSegments               int                          `json:"missingSegments"`
	ReportedSizePerReplicaInBytes int64                        `json:"reportedSizePerReplicaInBytes"`
	Segments                      map[string]SegmentSizeDetail `json:"segments"`
}

type TableSegmentsConfig

type TableSegmentsConfig struct {
	TimeType                       string `json:"timeType"`
	Replication                    string `json:"replication"`
	ReplicasPerPartition           string `json:"replicasPerPartition,omitempty"`
	TimeColumnName                 string `json:"timeColumnName"`
	SegmentAssignmentStrategy      string `json:"segmentAssignmentStrategy,omitempty"`
	SegmentPushType                string `json:"segmentPushType,omitempty"`
	MinimizeDataMovement           bool   `json:"minimizeDataMovement"`
	RetentionTimeUnit              string `json:"retentionTimeUnit,omitempty"`
	RetentionTimeValue             string `json:"retentionTimeValue,omitempty"`
	CrypterClassName               string `json:"crypterClassName,omitempty"`
	PeerSegmentDownloadScheme      string `json:"peerSegmentDownloadScheme,omitempty"`
	CompletionMode                 string `json:"completionMode,omitempty"`
	DeletedSegmentsRetentionPeriod string `json:"deletedSegmentsRetentionPeriod,omitempty"`
}

type TableStats added in v0.5.0

type TableStats struct {
	CreationTime string `json:"creationTime"`
}

type TableTenant

type TableTenant struct {
	Broker string `json:"broker"`
	Server string `json:"server"`
}

type Task added in v0.6.1

type Task struct {
	TaskConfigMap map[string]string `json:"taskConfigMap"`
}

type Tenant added in v0.1.5

type Tenant struct {
	TenantName string `json:"tenantName"`
	TenantRole string `json:"tenantRole"`
}

type TierConfig

type TierConfig struct {
	Name                string `json:"name"`
	SegmentSelectorType string `json:"segmentSelectorType"`
	SegmentAge          string `json:"segmentAge"`
	StorageType         string `json:"storageType"`
	ServerTag           string `json:"serverTag"`
}

type TierOverwrite

type TierOverwrite struct {
	StarTreeIndexConfigs []*StarTreeIndexConfig `json:"starTreeIndexConfigs"`
}

type TierOverwrites

type TierOverwrites struct {
	HotTier  *TierOverwrite `json:"hotTier,omitempty"`
	ColdTier *TierOverwrite `json:"coldTier,omitempty"`
}

type TimestampConfig

type TimestampConfig struct {
	Granularities []string `json:"granularities"`
}

type TransformConfig

type TransformConfig struct {
	ColumnName        string `json:"columnName"`
	TransformFunction string `json:"transformFunction"`
}

type UpsertConfig added in v0.1.5

type UpsertConfig struct {
	Mode                         string            `json:"mode"`
	PartialUpsertStrategies      map[string]string `json:"partialUpsertStrategies,omitempty"`
	DefaultPartialUpsertStrategy string            `json:"defaultPartialUpsertStrategy,omitempty"`
	ComparisonColumns            string            `json:"comparisonColumn,omitempty"`
	DeleteRecordColumn           string            `json:"deleteRecordColumn,omitempty"`
	DeletedKeysTTL               float64           `json:"deletedKeysTTL,omitempty"`
	HashFunction                 string            `json:"hashFunction,omitempty"`
	EnableSnapshot               *bool             `json:"enableSnapshot,omitempty"`
	EnablePreLoad                *bool             `json:"enablePreLoad,omitempty"`
	UpsertTTL                    string            `json:"upsertTTL,omitempty"`
	DropOutOfOrderRecord         *bool             `json:"dropOutOfOrderRecord,omitempty"`
	OutOfOrderRecordColumn       string            `json:"outOfOrderRecordColumn,omitempty"`
	MetadataManagerClass         string            `json:"metadataManagerClass,omitempty"`
	MetadataManagerConfigs       map[string]string `json:"metadataManagerConfigs,omitempty"`
}

type User

type User struct {
	Username              string `json:"username"`
	Password              string `json:"password"`
	Component             string `json:"component"`
	Role                  string `json:"role"`
	UsernameWithComponent string `json:"usernameWithComponent"`
}

type UserActionResponse

type UserActionResponse struct {
	Status string `json:"status"`
}

type ValidateSchemaResponse

type ValidateSchemaResponse struct {
	Ok    bool
	Error string
}

type ZkSegmentMetadata added in v0.6.0

type ZkSegmentMetadata struct {
	CustomMap           string `json:"custom.map"`
	SegmentCRC          string `json:"segment.crc"`
	SegmentCreationTime string `json:"segment.creation.time"`
	SegmentDownloadURL  string `json:"segment.download.url"`
	SegmentEndTime      string `json:"segment.end.time"`
	SegmentEndTimeRaw   string `json:"segment.end.time.raw"`
	SegmentIndexVersion string `json:"segment.index.version"`
	SegmentPushTime     string `json:"segment.push.time"`
	SegmentSizeInBytes  string `json:"segment.size.bytes"`
	SegmentStartTime    string `json:"segment.start.time"`
	SegmentStartTimeRaw string `json:"segment.start.time.raw"`
	SegmentTier         string `json:"segment.tier"`
	SegmentTimeUnit     string `json:"segment.time.unit"`
	SegmentTotalDocs    string `json:"segment.total.docs"`
}

Jump to

Keyboard shortcuts

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