Documentation ¶
Index ¶
- Constants
- Variables
- func Assert(cond bool, msg string)
- func BuildFlatbufferRows(rows []*TimeseriesRow, timeseriesTableName string, ...) ([]byte, error)
- func BuildTagString(tags map[string]string) (string, error)
- func BuildTags(tags map[string]string) ([]*otsprotocol.TimeseriesTag, error)
- func CheckTagKeyOrValue(s string) error
- func ConvertIndexTypeToPBIndexType(indexType IndexType) otsprotocol.IndexType
- func ConvertIndexTypeToPBIndexUpdateMode(indexType IndexType) otsprotocol.IndexUpdateMode
- func ConvertToPbCastType(variantType VariantType) *otsprotocol.VariantType
- func ConvertToPbSchema(schema *IndexSchema) (*otsprotocol.IndexSchema, error)
- func CreateBytesValue(builder *flatbuffers.Builder, offset flatbuffers.UOffsetT) flatbuffers.UOffsetT
- func CreateBytesValueVector(builder *flatbuffers.Builder, data []byte) flatbuffers.UOffsetT
- func NewCompositeFilter(filters []ColumnFilter, lo LogicalOperator) *otsprotocol.CompositeColumnValueFilter
- func NewPaginationFilter(filter *PaginationFilter) *otsprotocol.ColumnPaginationFilter
- func NewSingleColumnValueFilter(condition *SingleColumnCondition) *otsprotocol.SingleColumnValueFilter
- func ShouldRetryViaErrorAndAction(errorCode string, errorMsg string, action string) bool
- func SortedMapString(Map map[string]string) ([]string, []string)
- func WriteRawLittleEndian32(w io.Writer, value int32)
- type AbortTransactionRequest
- type AbortTransactionResponse
- type ActionType
- type AddDefinedColumnRequest
- type AddDefinedColumnResponse
- type AnalyticalStoreStorageSize
- type AnalyticalStoreSyncStat
- type AnalyticalStoreSyncType
- type Analyzer
- type AttributeColumn
- type AttributeMetaQueryCondition
- type BatchGetRowRequest
- type BatchGetRowResponse
- type BatchWriteRowRequest
- type BatchWriteRowResponse
- type ClientOption
- type Column
- type ColumnFilter
- type ColumnMap
- type ColumnToUpdate
- type ColumnType
- type ColumnValue
- type ColumnsToGet
- type CommitTransactionRequest
- type CommitTransactionResponse
- type ComparatorType
- type CompositeColumnValueFilter
- type CompositeMetaQueryCondition
- func (compositeMetaQueryCondition *CompositeMetaQueryCondition) AddSubConditions(subconditions ...MetaQueryCondition)
- func (compositeMetaQueryCondition *CompositeMetaQueryCondition) GetOperator() MetaQueryCompositeOperator
- func (compositeMetaQueryCondition *CompositeMetaQueryCondition) GetType() MetaQueryConditionType
- func (op *CompositeMetaQueryCondition) MarshalJSON() (data []byte, err error)
- func (compositemetaQueryCondition *CompositeMetaQueryCondition) Serialize() []byte
- func (compositeMetaQueryCondition *CompositeMetaQueryCondition) SetOperator(operator MetaQueryCompositeOperator)
- func (op *CompositeMetaQueryCondition) UnmarshalJSON(data []byte) (err error)
- type CompressType
- type ComputeSplitPointsBySizeRequest
- type ComputeSplitPointsBySizeResponse
- type ComputeSplitsRequest
- type ComputeSplitsResponse
- type ConsumedCapacityUnit
- type CreateDeliveryTaskRequest
- type CreateDeliveryTaskResponse
- type CreateIndexRequest
- type CreateIndexResponse
- type CreateSearchIndexRequest
- type CreateSearchIndexResponse
- type CreateTableRequest
- type CreateTableResponse
- type CreateTimeseriesAnalyticalStoreRequest
- type CreateTimeseriesAnalyticalStoreResponse
- type CreateTimeseriesLastpointIndexRequest
- type CreateTimeseriesLastpointIndexResponse
- type CreateTimeseriesTableRequest
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetAnalyticalStores() []*TimeseriesAnalyticalStore
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetEnableAnalyticalStore() bool
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetLastpointIndexNames() []string
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetTimeseriesTableMeta() *TimeseriesTableMeta
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetAnalyticalStores(analyticalStores []*TimeseriesAnalyticalStore)
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetEnableAnalyticalStore(enableAnalyticalStore bool)
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetLastpointIndexNames(lastpointIndexNames []string)
- func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetTimeseriesTableMeta(timeseriesTableMeta *TimeseriesTableMeta)
- type CreateTimeseriesTableResponse
- type CustomizedRetryNotMatterActions
- type DataBlockType
- type DataSourceMetaQueryCondition
- type DefinedColumnSchema
- type DefinedColumnType
- type DeleteDefinedColumnRequest
- type DeleteDefinedColumnResponse
- type DeleteDeliveryTaskRequest
- type DeleteDeliveryTaskResponse
- type DeleteIndexRequest
- type DeleteIndexResponse
- type DeleteRowChange
- type DeleteRowRequest
- type DeleteRowResponse
- type DeleteSearchIndexRequest
- type DeleteSearchIndexResponse
- type DeleteTableRequest
- type DeleteTableResponse
- type DeleteTimeseriesAnalyticalStoreRequest
- type DeleteTimeseriesAnalyticalStoreResponse
- type DeleteTimeseriesLastpointIndexRequest
- type DeleteTimeseriesLastpointIndexResponse
- type DeleteTimeseriesMetaRequest
- func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) AddTimeseriesKeys(keys ...*TimeseriesKey)
- func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) GetTimeseriesKeys() []*TimeseriesKey
- func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) GetTimeseriesTableName() string
- func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
- type DeleteTimeseriesMetaResponse
- type DeleteTimeseriesTableRequest
- type DeleteTimeseriesTableResponse
- type DeliveryTaskInfo
- type DescribeDeliveryTaskRequest
- type DescribeDeliveryTaskResponse
- type DescribeSearchIndexRequest
- type DescribeSearchIndexResponse
- type DescribeStreamRequest
- type DescribeStreamResponse
- type DescribeTableRequest
- type DescribeTableResponse
- type DescribeTimeseriesAnalyticalStoreRequest
- type DescribeTimeseriesAnalyticalStoreResponse
- type DescribeTimeseriesTableRequest
- type DescribeTimeseriesTableResponse
- func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetAnalyticalStores() []TimeseriesAnalyticalStore
- func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetLastpointIndexNames() []string
- func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetTimeseriesTableMeta() *TimeseriesTableMeta
- type Direction
- type Encoding
- type Error
- type ErrorType
- type EventColumn
- type ExtraRequestInfo
- type FailedRowResult
- type FieldSchema
- type FieldToGet
- type FieldType
- type FilterType
- type Format
- type FuzzyAnalyzerParameter
- type GetHttpClient
- type GetRangeRequest
- type GetRangeResponse
- type GetRowRequest
- type GetRowResponse
- type GetShardIteratorRequest
- type GetShardIteratorResponse
- type GetStreamRecordRequest
- type GetStreamRecordResponse
- type GetTimeseriesDataRequest
- func (getDataRequest *GetTimeseriesDataRequest) AddFieldToGet(field *FieldToGet)
- func (getDataRequest *GetTimeseriesDataRequest) GetBackward() bool
- func (getDataRequest *GetTimeseriesDataRequest) GetBeginTimeInUs() int64
- func (getDataRequest *GetTimeseriesDataRequest) GetEndTimeInUs() int64
- func (getDataRequest *GetTimeseriesDataRequest) GetFieldsToGet() []*FieldToGet
- func (getDataRequest *GetTimeseriesDataRequest) GetLimit() int32
- func (getDataRequest *GetTimeseriesDataRequest) GetNextToken() []byte
- func (getDataRequest *GetTimeseriesDataRequest) GetTimeRange() (int64, int64)
- func (getDataRequest *GetTimeseriesDataRequest) GetTimeseriesKey() *TimeseriesKey
- func (getDataRequest *GetTimeseriesDataRequest) GetTimeseriesTableName() string
- func (getDataRequest *GetTimeseriesDataRequest) SetBackward(backward bool)
- func (getDataRequest *GetTimeseriesDataRequest) SetFieldsToGet(fields []*FieldToGet)
- func (getDataRequest *GetTimeseriesDataRequest) SetLimit(limit int32)
- func (getDataRequest *GetTimeseriesDataRequest) SetNextToken(nextToken []byte)
- func (getDataRequest *GetTimeseriesDataRequest) SetTimeRange(beginTimeInUs int64, endTimeInUs int64)
- func (getDataRequest *GetTimeseriesDataRequest) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
- func (getDataRequest *GetTimeseriesDataRequest) SetTimeseriesTableName(timeseriesTableName string)
- type GetTimeseriesDataResponse
- type HTTPTimeout
- type HighlightField
- type HighlightResultItem
- type IHttpClient
- type IndexInfo
- type IndexMeta
- type IndexOptions
- type IndexSchema
- type IndexSetting
- type IndexType
- type ListDeliveryTaskRequest
- type ListDeliveryTaskResponse
- type ListSearchIndexRequest
- type ListSearchIndexResponse
- type ListStreamRequest
- type ListStreamResponse
- type ListTableResponse
- type ListTimeseriesTableRequest
- type ListTimeseriesTableResponse
- type LogicalOperator
- type MeasurementMetaQueryCondition
- type MetaQueryCompositeOperator
- type MetaQueryCondition
- type MetaQueryConditionType
- type MetaQueryConditionWrapper
- type MetaQuerySingleOperator
- type MeteringInfo
- type MultiRowQueryCriteria
- type OSSTaskConfig
- type OtsError
- type PaginationFilter
- type ParallelScanRequest
- func (r *ParallelScanRequest) ProtoBuffer() (*otsprotocol.ParallelScanRequest, error)
- func (r *ParallelScanRequest) SetColumnsToGet(columnsToGet *ColumnsToGet) *ParallelScanRequest
- func (r *ParallelScanRequest) SetIndexName(indexName string) *ParallelScanRequest
- func (r *ParallelScanRequest) SetScanQuery(scanQuery search.ScanQuery) *ParallelScanRequest
- func (r *ParallelScanRequest) SetSessionId(sessionId []byte) *ParallelScanRequest
- func (r *ParallelScanRequest) SetTableName(tableName string) *ParallelScanRequest
- func (r *ParallelScanRequest) SetTimeoutMs(timeoutMs int32) *ParallelScanRequest
- type ParallelScanResponse
- type ParquetDataType
- type PlainBufferCell
- type PlainBufferRow
- type PrimaryKey
- func (pk *PrimaryKey) AddPrimaryKeyColumn(primaryKeyName string, value interface{})
- func (pk *PrimaryKey) AddPrimaryKeyColumnWithAutoIncrement(primaryKeyName string)
- func (pk *PrimaryKey) AddPrimaryKeyColumnWithMaxValue(primaryKeyName string)
- func (pk *PrimaryKey) AddPrimaryKeyColumnWithMinValue(primaryKeyName string)
- func (pk *PrimaryKey) Build(isDelete bool) []byte
- type PrimaryKey2
- type PrimaryKeyColumn
- type PrimaryKeyColumnInner
- func NewPrimaryKeyColumn(name []byte, value interface{}, option PrimaryKeyOption) *PrimaryKeyColumnInner
- func NewPrimaryKeyColumnAuto_Increment(name []byte) *PrimaryKeyColumnInner
- func NewPrimaryKeyColumnINF_MAX(name []byte) *PrimaryKeyColumnInner
- func NewPrimaryKeyColumnINF_MIN(name []byte) *PrimaryKeyColumnInner
- type PrimaryKeyOption
- type PrimaryKeySchema
- type PrimaryKeyType
- type Priority
- type PutRowChange
- func (rowchange *PutRowChange) AddColumn(columnName string, value interface{})
- func (rowchange *PutRowChange) AddColumnWithTimestamp(columnName string, value interface{}, timestamp int64)
- func (rowchange *PutRowChange) GetTableName() string
- func (rowchange *PutRowChange) Serialize() []byte
- func (rowchange *PutRowChange) SetColumnCondition(condition ColumnFilter)
- func (rowchange *PutRowChange) SetCondition(rowExistenceExpectation RowExistenceExpectation)
- func (rowchange *PutRowChange) SetReturnPk()
- type PutRowRequest
- type PutRowResponse
- type PutTimeseriesDataRequest
- func (putTimeseriesDataRequest *PutTimeseriesDataRequest) AddTimeseriesRows(timeseriesRows ...*TimeseriesRow)
- func (putTimeseriesDataRequest *PutTimeseriesDataRequest) GetTimeseriesRows() []*TimeseriesRow
- func (putTimeseriesDataRequest *PutTimeseriesDataRequest) GetTimeseriesTableName() string
- func (putTimeseriesDataRequest *PutTimeseriesDataRequest) SetTimeseriesTableName(timeseriesTableName string)
- type PutTimeseriesDataResponse
- type QueryFlowWeight
- type QueryTimeseriesMetaRequest
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetCondition() MetaQueryCondition
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetLimit() int32
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetNextToken() []byte
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetTimeseriesTableName() string
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetTotalHits() bool
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetCondition(condition MetaQueryCondition)
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetLimit(limit int32)
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetNextToken(nextToken []byte)
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
- func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetTotalHits(getTotalHits bool)
- type QueryTimeseriesMetaResponse
- type RangeRowQueryCriteria
- type RecordColumn
- type RecordColumnType
- type RecordSequenceInfo
- type RequestExtension
- type ReservedThroughput
- type ResponseInfo
- type RetryNotify
- type ReturnType
- type Row
- type RowChange
- type RowCondition
- type RowExistenceExpectation
- type RowPutChange
- type RowResult
- type RowUpdateChange
- type SQLColumnInfo
- type SQLPayloadVersion
- type SQLQueryConsumed
- type SQLQueryRequest
- type SQLQueryResponse
- type SQLResultSet
- type SQLRow
- type SQLStatementType
- type SQLTableMeta
- type SSEDetails
- type SSEKeyType
- type SSESpecification
- type SearchConsumedCU
- type SearchHit
- type SearchIndexSplitsOptions
- type SearchInnerHit
- type SearchRequest
- func (r *SearchRequest) AddRoutingValue(routingValue *PrimaryKey) *SearchRequest
- func (r *SearchRequest) ProtoBuffer() (*otsprotocol.SearchRequest, error)
- func (r *SearchRequest) SetColumnsToGet(columnToGet *ColumnsToGet) *SearchRequest
- func (r *SearchRequest) SetIndexName(indexName string) *SearchRequest
- func (r *SearchRequest) SetRoutingValues(routingValues []*PrimaryKey) *SearchRequest
- func (r *SearchRequest) SetSearchQuery(searchQuery search.SearchQuery) *SearchRequest
- func (r *SearchRequest) SetTableName(tableName string) *SearchRequest
- func (r *SearchRequest) SetTimeoutMs(timeoutMs int32) *SearchRequest
- type SearchResponse
- type ShardId
- type ShardIterator
- type SingleColumnCondition
- type SingleRowQueryCriteria
- func (rowQueryCriteria *SingleRowQueryCriteria) AddColumnToGet(columnName string)
- func (rowQueryCriteria *SingleRowQueryCriteria) SetEndtColumn(columnName string)
- func (Criteria *SingleRowQueryCriteria) SetFilter(filter ColumnFilter)
- func (rowQueryCriteria *SingleRowQueryCriteria) SetStartColumn(columnName string)
- type SingleWordAnalyzerParameter
- type Split
- type SplitAnalyzerParameter
- type StartLocalTransactionRequest
- type StartLocalTransactionResponse
- type Stream
- type StreamDetails
- type StreamId
- type StreamRecord
- type StreamShard
- type StreamSpecification
- type StreamStatus
- type SyncPhase
- type SyncStat
- type TableConsumedCU
- type TableMeta
- type TableOption
- type TableStoreApi
- type TableStoreClient
- func NewClient(endPoint, instanceName, accessKeyId, accessKeySecret string, ...) *TableStoreClient
- func NewClientWithConfig(endPoint, instanceName, accessKeyId, accessKeySecret string, ...) *TableStoreClient
- func NewClientWithExternalHeader(endPoint, instanceName, accessKeyId, accessKeySecret string, ...) *TableStoreClient
- func (client *TableStoreClient) AbortTransaction(request *AbortTransactionRequest) (*AbortTransactionResponse, error)
- func (tableStoreClient *TableStoreClient) AddDefinedColumn(request *AddDefinedColumnRequest) (*AddDefinedColumnResponse, error)
- func (tableStoreClient *TableStoreClient) BatchGetRow(request *BatchGetRowRequest) (*BatchGetRowResponse, error)
- func (tableStoreClient *TableStoreClient) BatchWriteRow(request *BatchWriteRowRequest) (*BatchWriteRowResponse, error)
- func (client *TableStoreClient) CommitTransaction(request *CommitTransactionRequest) (*CommitTransactionResponse, error)
- func (client TableStoreClient) ComputeSplitPointsBySize(req *ComputeSplitPointsBySizeRequest) (*ComputeSplitPointsBySizeResponse, error)
- func (client *TableStoreClient) ComputeSplits(request *ComputeSplitsRequest) (*ComputeSplitsResponse, error)
- func (client *TableStoreClient) CreateDeliveryTask(request *CreateDeliveryTaskRequest) (*CreateDeliveryTaskResponse, error)
- func (tableStoreClient *TableStoreClient) CreateIndex(request *CreateIndexRequest) (*CreateIndexResponse, error)
- func (tableStoreClient *TableStoreClient) CreateSearchIndex(request *CreateSearchIndexRequest) (*CreateSearchIndexResponse, error)
- func (tableStoreClient *TableStoreClient) CreateTable(request *CreateTableRequest) (*CreateTableResponse, error)
- func (tableStoreClient *TableStoreClient) DeleteDefinedColumn(request *DeleteDefinedColumnRequest) (*DeleteDefinedColumnResponse, error)
- func (client *TableStoreClient) DeleteDeliveryTask(request *DeleteDeliveryTaskRequest) (*DeleteDeliveryTaskResponse, error)
- func (tableStoreClient *TableStoreClient) DeleteIndex(request *DeleteIndexRequest) (*DeleteIndexResponse, error)
- func (tableStoreClient *TableStoreClient) DeleteRow(request *DeleteRowRequest) (*DeleteRowResponse, error)
- func (tableStoreClient *TableStoreClient) DeleteSearchIndex(request *DeleteSearchIndexRequest) (*DeleteSearchIndexResponse, error)
- func (tableStoreClient *TableStoreClient) DeleteTable(request *DeleteTableRequest) (*DeleteTableResponse, error)
- func (client *TableStoreClient) DescribeDeliveryTask(request *DescribeDeliveryTaskRequest) (*DescribeDeliveryTaskResponse, error)
- func (tableStoreClient *TableStoreClient) DescribeSearchIndex(request *DescribeSearchIndexRequest) (*DescribeSearchIndexResponse, error)
- func (client *TableStoreClient) DescribeStream(req *DescribeStreamRequest) (*DescribeStreamResponse, error)
- func (tableStoreClient *TableStoreClient) DescribeTable(request *DescribeTableRequest) (*DescribeTableResponse, error)
- func (tableStoreClient *TableStoreClient) GetExternalHeader() map[string]string
- func (tableStoreClient *TableStoreClient) GetRange(request *GetRangeRequest) (*GetRangeResponse, error)
- func (tableStoreClient *TableStoreClient) GetRetryNotify() RetryNotify
- func (tableStoreClient *TableStoreClient) GetRow(request *GetRowRequest) (*GetRowResponse, error)
- func (client *TableStoreClient) GetShardIterator(req *GetShardIteratorRequest) (*GetShardIteratorResponse, error)
- func (client TableStoreClient) GetStreamRecord(req *GetStreamRecordRequest) (*GetStreamRecordResponse, error)
- func (client *TableStoreClient) ListDeliveryTask(request *ListDeliveryTaskRequest) (*ListDeliveryTaskResponse, error)
- func (tableStoreClient *TableStoreClient) ListSearchIndex(request *ListSearchIndexRequest) (*ListSearchIndexResponse, error)
- func (client *TableStoreClient) ListStream(req *ListStreamRequest) (*ListStreamResponse, error)
- func (tableStoreClient *TableStoreClient) ListTable() (*ListTableResponse, error)
- func (TableStoreClient *TableStoreClient) ParallelScan(request *ParallelScanRequest) (*ParallelScanResponse, error)
- func (tableStoreClient *TableStoreClient) PutRow(request *PutRowRequest) (*PutRowResponse, error)
- func (client *TableStoreClient) SQLQuery(req *SQLQueryRequest) (*SQLQueryResponse, error)
- func (tableStoreClient *TableStoreClient) Search(request *SearchRequest) (*SearchResponse, error)
- func (tableStoreClient *TableStoreClient) SetRetryNotify(retryNotify RetryNotify)
- func (client *TableStoreClient) StartLocalTransaction(request *StartLocalTransactionRequest) (*StartLocalTransactionResponse, error)
- func (tableStoreClient *TableStoreClient) UpdateRow(request *UpdateRowRequest) (*UpdateRowResponse, error)
- func (tableStoreClient *TableStoreClient) UpdateSearchIndex(request *UpdateSearchIndexRequest) (*UpdateSearchIndexResponse, error)
- func (tableStoreClient *TableStoreClient) UpdateTable(request *UpdateTableRequest) (*UpdateTableResponse, error)
- type TableStoreConfig
- type TableStoreHttpClient
- type TablestoreSQLResultSet
- type TagMetaQueryCondition
- type TaskSchema
- type TaskSyncPhase
- type TaskSyncStat
- type TaskType
- type TimeFormat
- type TimeRange
- type TimeseriesAnalyticalStore
- type TimeseriesClient
- func (timeseriesClient *TimeseriesClient) CreateTimeseriesAnalyticalStore(request *CreateTimeseriesAnalyticalStoreRequest) (*CreateTimeseriesAnalyticalStoreResponse, error)
- func (timeseriesClient *TimeseriesClient) CreateTimeseriesLastpointIndex(request *CreateTimeseriesLastpointIndexRequest) (*CreateTimeseriesLastpointIndexResponse, error)
- func (timeseriesClient *TimeseriesClient) CreateTimeseriesTable(request *CreateTimeseriesTableRequest) (*CreateTimeseriesTableResponse, error)
- func (timeseriesClient *TimeseriesClient) DeleteTimeseriesAnalyticalStore(request *DeleteTimeseriesAnalyticalStoreRequest) (*DeleteTimeseriesAnalyticalStoreResponse, error)
- func (timeseriesClient *TimeseriesClient) DeleteTimeseriesLastpointIndex(request *DeleteTimeseriesLastpointIndexRequest) (*DeleteTimeseriesLastpointIndexResponse, error)
- func (timeseriesClient *TimeseriesClient) DeleteTimeseriesMeta(request *DeleteTimeseriesMetaRequest) (*DeleteTimeseriesMetaResponse, error)
- func (timeseriesClient *TimeseriesClient) DeleteTimeseriesTable(request *DeleteTimeseriesTableRequest) (*DeleteTimeseriesTableResponse, error)
- func (timeseriesClient *TimeseriesClient) DescribeTimeseriesAnalyticalStore(request *DescribeTimeseriesAnalyticalStoreRequest) (*DescribeTimeseriesAnalyticalStoreResponse, error)
- func (timeseriesClient *TimeseriesClient) DescribeTimeseriesTable(request *DescribeTimeseriesTableRequest) (*DescribeTimeseriesTableResponse, error)
- func (timeseriesClient *TimeseriesClient) GetTimeseriesData(request *GetTimeseriesDataRequest) (*GetTimeseriesDataResponse, error)
- func (timeseriesClient *TimeseriesClient) GetTimeseriesMetaCache() *lruCache.Cache
- func (timeseriesClient *TimeseriesClient) ListTimeseriesTable() (*ListTimeseriesTableResponse, error)
- func (timeseriesClient *TimeseriesClient) PutTimeseriesData(request *PutTimeseriesDataRequest) (*PutTimeseriesDataResponse, error)
- func (timeseriesClient *TimeseriesClient) QueryTimeseriesMeta(request *QueryTimeseriesMetaRequest) (*QueryTimeseriesMetaResponse, error)
- func (timeseriesClient *TimeseriesClient) SetTimeseriesMetaCache(timeseriesMetaCache *lruCache.Cache)
- func (timeseriesClient *TimeseriesClient) UpdateTimeseriesAnalyticalStore(request *UpdateTimeseriesAnalyticalStoreRequest) (*UpdateTimeseriesAnalyticalStoreResponse, error)
- func (timeseriesClient *TimeseriesClient) UpdateTimeseriesMeta(request *UpdateTimeseriesMetaRequest) (*UpdateTimeseriesMetaResponse, error)
- func (timeseriesClient *TimeseriesClient) UpdateTimeseriesTable(request *UpdateTimeseriesTableRequest) (*UpdateTimeseriesTableResponse, error)
- type TimeseriesClientOption
- type TimeseriesConfiguration
- type TimeseriesKey
- func (timeseriesKey *TimeseriesKey) AddTag(tagName string, tagValue string)
- func (timeseriesKey *TimeseriesKey) AddTags(tagsMap map[string]string)
- func (timeseriesKey *TimeseriesKey) GetDataSource() string
- func (timeseriesKey *TimeseriesKey) GetMeasurementName() string
- func (timeseriesKey *TimeseriesKey) GetTags() map[string]string
- func (timeseriesKey *TimeseriesKey) SetDataSource(source string)
- func (timeseriesKey *TimeseriesKey) SetMeasurementName(measurementName string)
- type TimeseriesMeta
- func (timeseriesMeta *TimeseriesMeta) AddAttribute(attr_key string, attr_value string)
- func (timeseriesMeta *TimeseriesMeta) AddAttributes(attributes map[string]string)
- func (timeseriesMeta *TimeseriesMeta) GetAttributeSlice() string
- func (timeseriesMeta *TimeseriesMeta) GetAttributes() map[string]string
- func (timeseriesMeta *TimeseriesMeta) GetTimeseriesKey() *TimeseriesKey
- func (timeseriesMeta *TimeseriesMeta) GetUpdateTimeInUs() int64
- func (timeseriesMeta *TimeseriesMeta) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
- func (timeseriesMeta *TimeseriesMeta) SetUpdateTimeInUs(updateTimeInUs int64)
- type TimeseriesRow
- func (timeseriesRow *TimeseriesRow) AddField(fieldName string, fieldValue *ColumnValue)
- func (timeseriesRow *TimeseriesRow) AddFields(fieldsMap map[string]*ColumnValue)
- func (timeseriesRow *TimeseriesRow) GetFieldsMap() map[string]*ColumnValue
- func (timeseriesRow *TimeseriesRow) GetTimeInus() int64
- func (timeseriesRow *TimeseriesRow) GetTimeseriesKey() *TimeseriesKey
- func (timeseriesRow *TimeseriesRow) SetTimeInus(timestamp int64)
- func (timeseriesRow *TimeseriesRow) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
- type TimeseriesTableMeta
- func (timeseriesTableMeta *TimeseriesTableMeta) AddFieldPrimaryKey(name string, primaryKeyType PrimaryKeyType)
- func (timeseriesTableMeta *TimeseriesTableMeta) AddTimeseriesKey(name string)
- func (timeseriesTableMeta *TimeseriesTableMeta) GetFieldPrimaryKeys() []*PrimaryKeySchema
- func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesKeys() []string
- func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesTableName() string
- func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesTableOPtions() *TimeseriesTableOptions
- func (timeseriesTableMeta *TimeseriesTableMeta) SetTimeseriesTableName(timeseriesTableName string)
- func (timeseriesTableMeta *TimeseriesTableMeta) SetTimeseriesTableOptions(timeseriesTableOptions *TimeseriesTableOptions)
- type TimeseriesTableOptions
- type UpdateRowChange
- func (rowchange *UpdateRowChange) AppendIncrementColumnToReturn(name string)
- func (rowchange *UpdateRowChange) DeleteColumn(columnName string)
- func (rowchange *UpdateRowChange) DeleteColumnWithTimestamp(columnName string, timestamp int64)
- func (rowchange *UpdateRowChange) GetTableName() string
- func (rowchange *UpdateRowChange) IncrementColumn(columnName string, value int64)
- func (rowchange *UpdateRowChange) PutColumn(columnName string, value interface{})
- func (rowchange *UpdateRowChange) PutColumnWithTimestamp(columnName string, value interface{}, timestamp int64)
- func (rowchange *UpdateRowChange) Serialize() []byte
- func (rowchange *UpdateRowChange) SetColumnCondition(condition ColumnFilter)
- func (rowchange *UpdateRowChange) SetCondition(rowExistenceExpectation RowExistenceExpectation)
- func (rowchange *UpdateRowChange) SetReturnIncrementValue()
- type UpdateRowRequest
- type UpdateRowResponse
- type UpdateSearchIndexRequest
- type UpdateSearchIndexResponse
- type UpdateTableRequest
- type UpdateTableResponse
- type UpdateTimeMetaQueryCondition
- type UpdateTimeseriesAnalyticalStoreRequest
- type UpdateTimeseriesAnalyticalStoreResponse
- type UpdateTimeseriesMetaRequest
- func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) AddTimeseriesMetas(metas ...*TimeseriesMeta)
- func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) GetTimeseriesMetas() []*TimeseriesMeta
- func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) GetTimeseriesTableName() string
- func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
- type UpdateTimeseriesMetaResponse
- type UpdateTimeseriesTableRequest
- func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) GetTimeseriesTableName() string
- func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) GetTimeseriesTableOptions() *TimeseriesTableOptions
- func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) SetTimeseriesTableOptions(timeseriesTableOptions *TimeseriesTableOptions)
- func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) SetTimeseriesTalbeName(timeseriesTableName string)
- type UpdateTimeseriesTableResponse
- type ValueTransferRule
- type VariantType
- type VectorDataType
- type VectorMetricType
- type VectorOptions
Constants ¶
const ( OTS_CLIENT_UNKNOWN = "OTSClientUnknownError" ROW_OPERATION_CONFLICT = "OTSRowOperationConflict" NOT_ENOUGH_CAPACITY_UNIT = "OTSNotEnoughCapacityUnit" TABLE_NOT_READY = "OTSTableNotReady" PARTITION_UNAVAILABLE = "OTSPartitionUnavailable" SERVER_BUSY = "OTSServerBusy" STORAGE_SERVER_BUSY = "OTSStorageServerBusy" QUOTA_EXHAUSTED = "OTSQuotaExhausted" STORAGE_TIMEOUT = "OTSTimeout" SERVER_UNAVAILABLE = "OTSServerUnavailable" INTERNAL_SERVER_ERROR = "OTSInternalServerError" )
const ( MatrixBlockApiVersion = 0x304d5253 TagChecksum byte = 1 // ignore TagRow byte = 2 TagRowCount byte = 3 TagEntirePrimaryKeys byte = 10 )
const ( DefaultRetryInterval = 10 MaxRetryInterval = 320 )
const ( XOtsHeaderAdminTaskType = "x-ots-admin-task-type" XOtsHeaderAdminTargetUserId = "x-ots-admin-target-userid" )
const ( HEADER = 0x75 // tag type TAG_ROW_PK = 0x1 TAG_ROW_DATA = 0x2 TAG_CELL = 0x3 TAG_CELL_NAME = 0x4 TAG_CELL_VALUE = 0x5 TAG_CELL_TYPE = 0x6 TAG_CELL_TIMESTAMP = 0x7 TAG_DELETE_ROW_MARKER = 0x8 TAG_ROW_CHECKSUM = 0x9 TAG_CELL_CHECKSUM = 0x0A TAG_EXTENSION = 0x0B TAG_SEQ_INFO = 0x0C TAG_SEQ_INFO_EPOCH = 0x0D TAG_SEQ_INFO_TS = 0x0E TAG_SEQ_INFO_ROW_INDEX = 0x0F // cell op type DELETE_ALL_VERSION = 0x1 DELETE_ONE_VERSION = 0x3 INCREMENT = 0x4 // variant type VT_INTEGER = 0x0 VT_DOUBLE = 0x1 VT_BOOLEAN = 0x2 VT_STRING = 0x3 //public final static byte VT_NULL = 0x6; VT_NULL = 0x6 VT_BLOB = 0x7 VT_INF_MIN = 0x9 VT_INF_MAX = 0xa VT_AUTO_INCREMENT = 0xb LITTLE_ENDIAN_32_SIZE = 4 LITTLE_ENDIAN_64_SIZE = 8 )
const ( Version = "1.0" ApiVersion = "2015-12-31" )
const ( MaxValue = "_get_range_max" MinValue = "_get_range_min" )
Variables ¶
var RowsSerializeType = otsprotocol.RowsSerializeType_RST_FLAT_BUFFER
RowsSerializeType is used for tests only.
Functions ¶
func BuildFlatbufferRows ¶ added in v1.7.0
func BuildTags ¶ added in v1.7.15
func BuildTags(tags map[string]string) ([]*otsprotocol.TimeseriesTag, error)
func CheckTagKeyOrValue ¶ added in v1.7.0
func ConvertIndexTypeToPBIndexType ¶
func ConvertIndexTypeToPBIndexType(indexType IndexType) otsprotocol.IndexType
func ConvertIndexTypeToPBIndexUpdateMode ¶
func ConvertIndexTypeToPBIndexUpdateMode(indexType IndexType) otsprotocol.IndexUpdateMode
func ConvertToPbCastType ¶
func ConvertToPbCastType(variantType VariantType) *otsprotocol.VariantType
func ConvertToPbSchema ¶ added in v1.7.5
func ConvertToPbSchema(schema *IndexSchema) (*otsprotocol.IndexSchema, error)
func CreateBytesValue ¶ added in v1.7.0
func CreateBytesValue(builder *flatbuffers.Builder, offset flatbuffers.UOffsetT) flatbuffers.UOffsetT
func CreateBytesValueVector ¶ added in v1.7.0
func CreateBytesValueVector(builder *flatbuffers.Builder, data []byte) flatbuffers.UOffsetT
func NewCompositeFilter ¶
func NewCompositeFilter(filters []ColumnFilter, lo LogicalOperator) *otsprotocol.CompositeColumnValueFilter
func NewPaginationFilter ¶
func NewPaginationFilter(filter *PaginationFilter) *otsprotocol.ColumnPaginationFilter
func NewSingleColumnValueFilter ¶
func NewSingleColumnValueFilter(condition *SingleColumnCondition) *otsprotocol.SingleColumnValueFilter
func ShouldRetryViaErrorAndAction ¶ added in v1.7.12
func SortedMapString ¶ added in v1.7.0
implement sortedMap : map[string]string
func WriteRawLittleEndian32 ¶ added in v1.7.8
Types ¶
type AbortTransactionRequest ¶
type AbortTransactionRequest struct { TransactionId *string ExtraRequestInfo }
type AbortTransactionResponse ¶
type AbortTransactionResponse struct {
ResponseInfo
}
type ActionType ¶
type ActionType int
const ( AT_Put ActionType = iota AT_Update AT_Delete )
func (ActionType) String ¶
func (this ActionType) String() string
type AddDefinedColumnRequest ¶
type AddDefinedColumnRequest struct { TableName string DefinedColumns []*DefinedColumnSchema ExtraRequestInfo }
func (*AddDefinedColumnRequest) AddDefinedColumn ¶
func (request *AddDefinedColumnRequest) AddDefinedColumn(name string, definedType DefinedColumnType)
type AddDefinedColumnResponse ¶
type AddDefinedColumnResponse struct {
ResponseInfo
}
type AnalyticalStoreStorageSize ¶ added in v1.7.8
type AnalyticalStoreSyncStat ¶ added in v1.7.8
type AnalyticalStoreSyncStat struct { SyncPhase AnalyticalStoreSyncType CurrentSyncTimestamp int64 }
type AnalyticalStoreSyncType ¶ added in v1.7.8
type AnalyticalStoreSyncType int32
const ( SYNC_TYPE_FULL AnalyticalStoreSyncType = 1 SYNC_TYPE_INCR AnalyticalStoreSyncType = 2 )
func (AnalyticalStoreSyncType) String ¶ added in v1.7.8
func (analyticalStoreSyncType AnalyticalStoreSyncType) String() string
type AttributeColumn ¶
type AttributeMetaQueryCondition ¶ added in v1.7.0
type AttributeMetaQueryCondition struct { Operator MetaQuerySingleOperator AttributeName string Value string }
func NewAttributeMetaQueryCondition ¶ added in v1.7.0
func NewAttributeMetaQueryCondition(operator MetaQuerySingleOperator, attributeName string, value string) *AttributeMetaQueryCondition
func (*AttributeMetaQueryCondition) GetType ¶ added in v1.7.0
func (attributeMetaQueryCondition *AttributeMetaQueryCondition) GetType() MetaQueryConditionType
func (*AttributeMetaQueryCondition) Serialize ¶ added in v1.7.0
func (attributeMetaQueryCondition *AttributeMetaQueryCondition) Serialize() []byte
type BatchGetRowRequest ¶
type BatchGetRowRequest struct { MultiRowQueryCriteria []*MultiRowQueryCriteria ExtraRequestInfo }
type BatchGetRowResponse ¶
type BatchGetRowResponse struct { TableToRowsResult map[string][]RowResult ResponseInfo }
type BatchWriteRowRequest ¶
type BatchWriteRowRequest struct { RowChangesGroupByTable map[string][]RowChange IsAtomic bool ExtraRequestInfo }
IsAtomic设置是否为批量原子写 如果设置了批量原子写,需要保证写入到同一张表格中的分区键相同,否则会写入失败
func (*BatchWriteRowRequest) AddRowChange ¶
func (request *BatchWriteRowRequest) AddRowChange(change RowChange)
type BatchWriteRowResponse ¶
type BatchWriteRowResponse struct { TableToRowsResult map[string][]RowResult ResponseInfo }
type ClientOption ¶
type ClientOption func(*TableStoreClient)
func SetCredentialsProvider ¶ added in v1.7.3
func SetCredentialsProvider(provider common.CredentialsProvider) ClientOption
SetCredentialsProvider sets funciton for get the user's ak
type Column ¶
type ColumnFilter ¶
type ColumnFilter interface { Serialize() []byte ToFilter() *otsprotocol.Filter }
type ColumnMap ¶
type ColumnMap struct { Columns map[string][]*AttributeColumn // contains filtered or unexported fields }
type ColumnToUpdate ¶
type ColumnType ¶
type ColumnType int32
const ( ColumnType_STRING ColumnType = 1 ColumnType_INTEGER ColumnType = 2 ColumnType_BOOLEAN ColumnType = 3 ColumnType_DOUBLE ColumnType = 4 ColumnType_BINARY ColumnType = 5 ColumnType_DATETIME ColumnType = 6 ColumnType_TIME ColumnType = 7 ColumnType_DATE ColumnType = 8 )
func (*ColumnType) String ¶ added in v1.7.7
func (t *ColumnType) String() string
type ColumnValue ¶
type ColumnValue struct { Type ColumnType Value interface{} }
func NewColumnValue ¶ added in v1.7.0
func NewColumnValue(columnType ColumnType, value interface{}) *ColumnValue
func ReadCellValue ¶ added in v1.7.8
func ReadCellValue(r *bytes.Reader) (colValue *ColumnValue, isInfMax bool)
func SortedMapColumnValue ¶ added in v1.7.0
func SortedMapColumnValue(Map map[string]*ColumnValue) ([]string, []*ColumnValue)
implement sorted map[string]ColumnValue
func (*ColumnValue) WriteCellValueWithoutLengthPrefix ¶ added in v1.7.8
func (cv *ColumnValue) WriteCellValueWithoutLengthPrefix() []byte
type ColumnsToGet ¶
type CommitTransactionRequest ¶
type CommitTransactionRequest struct { TransactionId *string ExtraRequestInfo }
type CommitTransactionResponse ¶
type CommitTransactionResponse struct {
ResponseInfo
}
type ComparatorType ¶
type ComparatorType int32
const ( CT_EQUAL ComparatorType = 1 CT_NOT_EQUAL ComparatorType = 2 CT_GREATER_THAN ComparatorType = 3 CT_GREATER_EQUAL ComparatorType = 4 CT_LESS_THAN ComparatorType = 5 CT_LESS_EQUAL ComparatorType = 6 )
func (*ComparatorType) ConvertToPbComparatorType ¶
func (comparatorType *ComparatorType) ConvertToPbComparatorType() otsprotocol.ComparatorType
type CompositeColumnValueFilter ¶
type CompositeColumnValueFilter struct { Operator LogicalOperator Filters []ColumnFilter }
func NewCompositeColumnCondition ¶
func NewCompositeColumnCondition(lo LogicalOperator) *CompositeColumnValueFilter
func (*CompositeColumnValueFilter) AddFilter ¶
func (ccvfilter *CompositeColumnValueFilter) AddFilter(filter ColumnFilter)
func (*CompositeColumnValueFilter) Serialize ¶
func (ccvfilter *CompositeColumnValueFilter) Serialize() []byte
func (*CompositeColumnValueFilter) ToFilter ¶
func (ccvfilter *CompositeColumnValueFilter) ToFilter() *otsprotocol.Filter
type CompositeMetaQueryCondition ¶ added in v1.7.0
type CompositeMetaQueryCondition struct { Operator MetaQueryCompositeOperator SubConditions []*MetaQueryCondition `json:"-"` // for json marshal and unmarshal SubConditionsAlias []*MetaQueryConditionWrapper `json:"SubConditions"` }
func NewCompositeMetaQueryCondition ¶ added in v1.7.0
func NewCompositeMetaQueryCondition(operator MetaQueryCompositeOperator, subConditions ...MetaQueryCondition) *CompositeMetaQueryCondition
func (*CompositeMetaQueryCondition) AddSubConditions ¶ added in v1.7.0
func (compositeMetaQueryCondition *CompositeMetaQueryCondition) AddSubConditions(subconditions ...MetaQueryCondition)
func (*CompositeMetaQueryCondition) GetOperator ¶ added in v1.7.0
func (compositeMetaQueryCondition *CompositeMetaQueryCondition) GetOperator() MetaQueryCompositeOperator
func (*CompositeMetaQueryCondition) GetType ¶ added in v1.7.0
func (compositeMetaQueryCondition *CompositeMetaQueryCondition) GetType() MetaQueryConditionType
func (*CompositeMetaQueryCondition) MarshalJSON ¶ added in v1.7.3
func (op *CompositeMetaQueryCondition) MarshalJSON() (data []byte, err error)
func (*CompositeMetaQueryCondition) Serialize ¶ added in v1.7.0
func (compositemetaQueryCondition *CompositeMetaQueryCondition) Serialize() []byte
func (*CompositeMetaQueryCondition) SetOperator ¶ added in v1.7.0
func (compositeMetaQueryCondition *CompositeMetaQueryCondition) SetOperator(operator MetaQueryCompositeOperator)
func (*CompositeMetaQueryCondition) UnmarshalJSON ¶ added in v1.7.3
func (op *CompositeMetaQueryCondition) UnmarshalJSON(data []byte) (err error)
type ComputeSplitPointsBySizeRequest ¶
type ComputeSplitPointsBySizeRequest struct { TableName string SplitSize int64 SplitSizeUnitInByte *int64 SplitPointLimit *int32 ExtraRequestInfo }
type ComputeSplitPointsBySizeResponse ¶
type ComputeSplitPointsBySizeResponse struct { SchemaEntry []*PrimaryKeySchema Splits []*Split ResponseInfo }
type ComputeSplitsRequest ¶ added in v1.6.0
type ComputeSplitsRequest struct { TableName string ExtraRequestInfo // contains filtered or unexported fields }
func (*ComputeSplitsRequest) SetSearchIndexSplitsOptions ¶ added in v1.6.0
func (r *ComputeSplitsRequest) SetSearchIndexSplitsOptions(options SearchIndexSplitsOptions) *ComputeSplitsRequest
func (*ComputeSplitsRequest) SetTableName ¶ added in v1.6.0
func (r *ComputeSplitsRequest) SetTableName(tableName string) *ComputeSplitsRequest
type ComputeSplitsResponse ¶ added in v1.6.0
type ComputeSplitsResponse struct { SessionId []byte SplitsSize int32 ResponseInfo }
type ConsumedCapacityUnit ¶
type CreateDeliveryTaskRequest ¶ added in v1.6.0
type CreateDeliveryTaskRequest struct { TableName string TaskName string TaskType TaskType TaskConfig *OSSTaskConfig ExtraRequestInfo }
type CreateDeliveryTaskResponse ¶ added in v1.6.0
type CreateDeliveryTaskResponse struct {
ResponseInfo
}
type CreateIndexRequest ¶
type CreateIndexRequest struct { MainTableName string IndexMeta *IndexMeta IncludeBaseData bool ExtraRequestInfo }
type CreateIndexResponse ¶
type CreateIndexResponse struct {
ResponseInfo
}
type CreateSearchIndexRequest ¶
type CreateSearchIndexRequest struct { TableName string IndexName string IndexSchema *IndexSchema SourceIndexName *string TimeToLive *int32 ExtraRequestInfo }
type CreateSearchIndexResponse ¶
type CreateSearchIndexResponse struct {
ResponseInfo ResponseInfo
}
type CreateTableRequest ¶
type CreateTableRequest struct { TableMeta *TableMeta TableOption *TableOption ReservedThroughput *ReservedThroughput StreamSpec *StreamSpecification IndexMetas []*IndexMeta SSESpecification *SSESpecification EnableLocalTxn *bool ExtraRequestInfo }
func (*CreateTableRequest) AddIndexMeta ¶
func (request *CreateTableRequest) AddIndexMeta(meta *IndexMeta)
type CreateTableResponse ¶
type CreateTableResponse struct {
ResponseInfo
}
type CreateTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
type CreateTimeseriesAnalyticalStoreRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewCreateTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
func NewCreateTimeseriesAnalyticalStoreRequest(timeseriesTableName string, analyticalStore *TimeseriesAnalyticalStore) *CreateTimeseriesAnalyticalStoreRequest
type CreateTimeseriesAnalyticalStoreResponse ¶ added in v1.7.8
type CreateTimeseriesAnalyticalStoreResponse struct {
ResponseInfo
}
type CreateTimeseriesLastpointIndexRequest ¶ added in v1.7.15
type CreateTimeseriesLastpointIndexRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewCreateTimeseriesLastpointIndexRequest ¶ added in v1.7.15
func NewCreateTimeseriesLastpointIndexRequest( timeseriesTableName string, lastpointIndexTableName string, includeBaseData bool) *CreateTimeseriesLastpointIndexRequest
func (*CreateTimeseriesLastpointIndexRequest) GetIncludeBaseData ¶ added in v1.7.15
func (req *CreateTimeseriesLastpointIndexRequest) GetIncludeBaseData() bool
func (*CreateTimeseriesLastpointIndexRequest) GetLastpointIndexTableName ¶ added in v1.7.15
func (req *CreateTimeseriesLastpointIndexRequest) GetLastpointIndexTableName() string
func (*CreateTimeseriesLastpointIndexRequest) GetTimeseriesTableName ¶ added in v1.7.15
func (req *CreateTimeseriesLastpointIndexRequest) GetTimeseriesTableName() string
type CreateTimeseriesLastpointIndexResponse ¶ added in v1.7.15
type CreateTimeseriesLastpointIndexResponse struct {
ResponseInfo
}
type CreateTimeseriesTableRequest ¶ added in v1.7.0
type CreateTimeseriesTableRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewCreateTimeseriesTableRequest ¶ added in v1.7.0
func NewCreateTimeseriesTableRequest() *CreateTimeseriesTableRequest
func (*CreateTimeseriesTableRequest) GetAnalyticalStores ¶ added in v1.7.8
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetAnalyticalStores() []*TimeseriesAnalyticalStore
func (*CreateTimeseriesTableRequest) GetEnableAnalyticalStore ¶ added in v1.7.8
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetEnableAnalyticalStore() bool
func (*CreateTimeseriesTableRequest) GetLastpointIndexNames ¶ added in v1.7.15
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetLastpointIndexNames() []string
func (*CreateTimeseriesTableRequest) GetTimeseriesTableMeta ¶ added in v1.7.0
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) GetTimeseriesTableMeta() *TimeseriesTableMeta
func (*CreateTimeseriesTableRequest) SetAnalyticalStores ¶ added in v1.7.8
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetAnalyticalStores(analyticalStores []*TimeseriesAnalyticalStore)
func (*CreateTimeseriesTableRequest) SetEnableAnalyticalStore ¶ added in v1.7.8
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetEnableAnalyticalStore(enableAnalyticalStore bool)
func (*CreateTimeseriesTableRequest) SetLastpointIndexNames ¶ added in v1.7.15
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetLastpointIndexNames(lastpointIndexNames []string)
func (*CreateTimeseriesTableRequest) SetTimeseriesTableMeta ¶ added in v1.7.0
func (createTimeseriesTableRequest *CreateTimeseriesTableRequest) SetTimeseriesTableMeta(timeseriesTableMeta *TimeseriesTableMeta)
type CreateTimeseriesTableResponse ¶ added in v1.7.0
type CreateTimeseriesTableResponse struct {
ResponseInfo
}
type DataBlockType ¶ added in v1.7.8
type DataBlockType int
const ( PlainBuffer DataBlockType = iota SimpleRowMatrix )
type DataSourceMetaQueryCondition ¶ added in v1.7.0
type DataSourceMetaQueryCondition struct { Operator MetaQuerySingleOperator Value string }
func NewDataSourceMetaQueryCondition ¶ added in v1.7.0
func NewDataSourceMetaQueryCondition(operator MetaQuerySingleOperator, value string) *DataSourceMetaQueryCondition
func (*DataSourceMetaQueryCondition) GetType ¶ added in v1.7.0
func (sourceMetaQueryCondition *DataSourceMetaQueryCondition) GetType() MetaQueryConditionType
func (*DataSourceMetaQueryCondition) Serialize ¶ added in v1.7.0
func (sourceMetaQueryCondition *DataSourceMetaQueryCondition) Serialize() []byte
type DefinedColumnSchema ¶
type DefinedColumnSchema struct { Name string ColumnType DefinedColumnType }
type DefinedColumnType ¶
type DefinedColumnType int32
const ( /** * 64位整数。 */ DefinedColumn_INTEGER DefinedColumnType = 1 /** * 浮点数。 */ DefinedColumn_DOUBLE DefinedColumnType = 2 /** * 布尔值。 */ DefinedColumn_BOOLEAN DefinedColumnType = 3 /** * 字符串。 */ DefinedColumn_STRING DefinedColumnType = 4 /** * BINARY。 */ DefinedColumn_BINARY DefinedColumnType = 5 )
func ConvertPbDefinedColumnType ¶
func ConvertPbDefinedColumnType(columnType otsprotocol.DefinedColumnType) DefinedColumnType
func (DefinedColumnType) ConvertToPbDefinedColumnType ¶
func (columnType DefinedColumnType) ConvertToPbDefinedColumnType() otsprotocol.DefinedColumnType
type DeleteDefinedColumnRequest ¶
type DeleteDefinedColumnRequest struct { TableName string DefinedColumns []string ExtraRequestInfo }
type DeleteDefinedColumnResponse ¶
type DeleteDefinedColumnResponse struct {
ResponseInfo
}
type DeleteDeliveryTaskRequest ¶ added in v1.6.0
type DeleteDeliveryTaskRequest struct { TableName string TaskName string ExtraRequestInfo }
type DeleteDeliveryTaskResponse ¶ added in v1.6.0
type DeleteDeliveryTaskResponse struct {
ResponseInfo
}
type DeleteIndexRequest ¶
type DeleteIndexRequest struct { MainTableName string IndexName string ExtraRequestInfo }
type DeleteIndexResponse ¶
type DeleteIndexResponse struct {
ResponseInfo
}
type DeleteRowChange ¶
type DeleteRowChange struct { TableName string PrimaryKey *PrimaryKey Condition *RowCondition TransactionId *string }
func (*DeleteRowChange) GetTableName ¶
func (rowchange *DeleteRowChange) GetTableName() string
func (*DeleteRowChange) Serialize ¶
func (rowchange *DeleteRowChange) Serialize() []byte
func (*DeleteRowChange) SetColumnCondition ¶
func (rowchange *DeleteRowChange) SetColumnCondition(condition ColumnFilter)
func (*DeleteRowChange) SetCondition ¶
func (rowchange *DeleteRowChange) SetCondition(rowExistenceExpectation RowExistenceExpectation)
type DeleteRowRequest ¶
type DeleteRowRequest struct { DeleteRowChange *DeleteRowChange ExtraRequestInfo }
type DeleteRowResponse ¶
type DeleteRowResponse struct { ConsumedCapacityUnit *ConsumedCapacityUnit ResponseInfo }
type DeleteSearchIndexRequest ¶
type DeleteSearchIndexRequest struct { TableName string IndexName string ExtraRequestInfo }
type DeleteSearchIndexResponse ¶
type DeleteSearchIndexResponse struct {
ResponseInfo ResponseInfo
}
type DeleteTableRequest ¶
type DeleteTableRequest struct { TableName string ExtraRequestInfo }
type DeleteTableResponse ¶
type DeleteTableResponse struct {
ResponseInfo
}
type DeleteTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
type DeleteTimeseriesAnalyticalStoreRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDeleteTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
func NewDeleteTimeseriesAnalyticalStoreRequest(timeseriesTableName string, analyticalStoreName string) *DeleteTimeseriesAnalyticalStoreRequest
func (*DeleteTimeseriesAnalyticalStoreRequest) SetDropMappingTable ¶ added in v1.7.11
func (deleteTimeseriesAnalyticalStoreRequest *DeleteTimeseriesAnalyticalStoreRequest) SetDropMappingTable(dropMappingTable bool)
type DeleteTimeseriesAnalyticalStoreResponse ¶ added in v1.7.8
type DeleteTimeseriesAnalyticalStoreResponse struct {
ResponseInfo
}
type DeleteTimeseriesLastpointIndexRequest ¶ added in v1.7.15
type DeleteTimeseriesLastpointIndexRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDeleteTimeseriesLastpointIndexRequest ¶ added in v1.7.15
func NewDeleteTimeseriesLastpointIndexRequest(timeseriesTableName string, lastpointIndexTableName string) *DeleteTimeseriesLastpointIndexRequest
func (*DeleteTimeseriesLastpointIndexRequest) GetLastpointIndexTableName ¶ added in v1.7.15
func (req *DeleteTimeseriesLastpointIndexRequest) GetLastpointIndexTableName() string
func (*DeleteTimeseriesLastpointIndexRequest) GetTimeseriesTableName ¶ added in v1.7.15
func (req *DeleteTimeseriesLastpointIndexRequest) GetTimeseriesTableName() string
type DeleteTimeseriesLastpointIndexResponse ¶ added in v1.7.15
type DeleteTimeseriesLastpointIndexResponse struct {
ResponseInfo
}
type DeleteTimeseriesMetaRequest ¶ added in v1.7.3
type DeleteTimeseriesMetaRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDeleteTimeseriesMetaRequest ¶ added in v1.7.3
func NewDeleteTimeseriesMetaRequest(timeseriesTableName string) *DeleteTimeseriesMetaRequest
func (*DeleteTimeseriesMetaRequest) AddTimeseriesKeys ¶ added in v1.7.3
func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) AddTimeseriesKeys(keys ...*TimeseriesKey)
func (*DeleteTimeseriesMetaRequest) GetTimeseriesKeys ¶ added in v1.7.3
func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) GetTimeseriesKeys() []*TimeseriesKey
func (*DeleteTimeseriesMetaRequest) GetTimeseriesTableName ¶ added in v1.7.3
func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) GetTimeseriesTableName() string
func (*DeleteTimeseriesMetaRequest) SetTimeseriesTableName ¶ added in v1.7.3
func (deleteTimeseriesMetaRequest *DeleteTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
type DeleteTimeseriesMetaResponse ¶ added in v1.7.3
type DeleteTimeseriesMetaResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*DeleteTimeseriesMetaResponse) GetFailedRowResults ¶ added in v1.7.3
func (deleteTimeseriesMetaResponse *DeleteTimeseriesMetaResponse) GetFailedRowResults() []*FailedRowResult
type DeleteTimeseriesTableRequest ¶ added in v1.7.0
type DeleteTimeseriesTableRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDeleteTimeseriesTableRequest ¶ added in v1.7.0
func NewDeleteTimeseriesTableRequest(timeseriesTableName string) *DeleteTimeseriesTableRequest
func (*DeleteTimeseriesTableRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (deleteTimeseriesTableRequest *DeleteTimeseriesTableRequest) GetTimeseriesTableName() string
func (*DeleteTimeseriesTableRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (deleteTimeseriesTableRequest *DeleteTimeseriesTableRequest) SetTimeseriesTableName(timeseriesTableName string)
type DeleteTimeseriesTableResponse ¶ added in v1.7.0
type DeleteTimeseriesTableResponse struct {
ResponseInfo
}
type DeliveryTaskInfo ¶ added in v1.6.0
type DescribeDeliveryTaskRequest ¶ added in v1.6.0
type DescribeDeliveryTaskRequest struct { TableName string TaskName string ExtraRequestInfo }
type DescribeDeliveryTaskResponse ¶ added in v1.6.0
type DescribeDeliveryTaskResponse struct { TaskConfig *OSSTaskConfig TaskSyncStat *TaskSyncStat TaskType TaskType ResponseInfo }
type DescribeSearchIndexRequest ¶
type DescribeSearchIndexRequest struct { TableName string IndexName string ExtraRequestInfo }
type DescribeSearchIndexResponse ¶
type DescribeSearchIndexResponse struct { Schema *IndexSchema SyncStat *SyncStat MeteringInfo *MeteringInfo QueryFlowWeights []*QueryFlowWeight CreateTime int64 TimeToLive int32 ResponseInfo ResponseInfo }
type DescribeStreamRequest ¶
type DescribeStreamRequest struct { StreamId *StreamId // required InclusiveStartShardId *ShardId // optional ShardLimit *int32 // optional ExtraRequestInfo }
type DescribeStreamResponse ¶
type DescribeStreamResponse struct { StreamId *StreamId // required ExpirationTime int32 // in hours TableName *string // required CreationTime int64 // in usec Status StreamStatus // required Shards []*StreamShard NextShardId *ShardId // optional. nil means "no more shards" ResponseInfo }
type DescribeTableRequest ¶
type DescribeTableRequest struct { TableName string ExtraRequestInfo }
type DescribeTableResponse ¶
type DescribeTableResponse struct { TableMeta *TableMeta TableOption *TableOption ReservedThroughput *ReservedThroughput StreamDetails *StreamDetails IndexMetas []*IndexMeta SSEDetails *SSEDetails ResponseInfo }
type DescribeTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
type DescribeTimeseriesAnalyticalStoreRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDescribeTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
func NewDescribeTimeseriesAnalyticalStoreRequest(timeseriesTableName string, analyticalStoreName string) *DescribeTimeseriesAnalyticalStoreRequest
type DescribeTimeseriesAnalyticalStoreResponse ¶ added in v1.7.8
type DescribeTimeseriesAnalyticalStoreResponse struct { ResponseInfo AnalyticalStore *TimeseriesAnalyticalStore SyncStat *AnalyticalStoreSyncStat StorageSize *AnalyticalStoreStorageSize }
type DescribeTimeseriesTableRequest ¶ added in v1.7.0
type DescribeTimeseriesTableRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewDescribeTimeseriesTableRequset ¶ added in v1.7.0
func NewDescribeTimeseriesTableRequset(timeseriesTableName string) *DescribeTimeseriesTableRequest
func (*DescribeTimeseriesTableRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (describeTimeseriesReq *DescribeTimeseriesTableRequest) GetTimeseriesTableName() string
func (*DescribeTimeseriesTableRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (describeTimeseriesReq *DescribeTimeseriesTableRequest) SetTimeseriesTableName(timeseriesTableName string)
type DescribeTimeseriesTableResponse ¶ added in v1.7.0
type DescribeTimeseriesTableResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*DescribeTimeseriesTableResponse) GetAnalyticalStores ¶ added in v1.7.8
func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetAnalyticalStores() []TimeseriesAnalyticalStore
func (*DescribeTimeseriesTableResponse) GetLastpointIndexNames ¶ added in v1.7.15
func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetLastpointIndexNames() []string
func (*DescribeTimeseriesTableResponse) GetTimeseriesTableMeta ¶ added in v1.7.0
func (describeTimeseriesTableResp *DescribeTimeseriesTableResponse) GetTimeseriesTableMeta() *TimeseriesTableMeta
type Direction ¶
type Direction int32
func (Direction) ToDirection ¶
func (direction Direction) ToDirection() otsprotocol.Direction
type ErrorType ¶ added in v1.6.0
type ErrorType int32
const ( ErrorTypeInvalidOssBucket ErrorType = 2 )
type EventColumn ¶ added in v1.6.0
type EventColumn struct { ColumnName string TimeFormat TimeFormat }
type ExtraRequestInfo ¶ added in v1.7.12
type ExtraRequestInfo struct {
// contains filtered or unexported fields
}
func (*ExtraRequestInfo) SetRequestExtension ¶ added in v1.7.12
func (ex *ExtraRequestInfo) SetRequestExtension(requestExtension RequestExtension)
func (*ExtraRequestInfo) SetTraceID ¶ added in v1.7.12
func (ex *ExtraRequestInfo) SetTraceID(traceID string)
type FailedRowResult ¶ added in v1.7.0
type FieldSchema ¶
type FieldSchema struct { FieldName *string FieldType FieldType Index *bool IndexOptions *IndexOptions Analyzer *Analyzer AnalyzerParameter interface{} EnableSortAndAgg *bool EnableHighlighting *bool Store *bool IsArray *bool FieldSchemas []*FieldSchema IsVirtualField *bool SourceFieldNames []string DateFormats []string VectorOptions *VectorOptions }
func (*FieldSchema) String ¶
func (fs *FieldSchema) String() string
func (*FieldSchema) UnmarshalJSON ¶ added in v1.7.3
func (r *FieldSchema) UnmarshalJSON(data []byte) (err error)
type FieldToGet ¶ added in v1.7.7
type FieldToGet struct { Name string Type ColumnType }
type FieldType ¶
type FieldType int32
func ToFieldType ¶ added in v1.7.3
func (*FieldType) MarshalJSON ¶ added in v1.7.3
func (*FieldType) UnmarshalJSON ¶ added in v1.7.3
type FilterType ¶
type FilterType int32
const ( FT_SINGLE_COLUMN_VALUE FilterType = 1 FT_COMPOSITE_COLUMN_VALUE FilterType = 2 FT_COLUMN_PAGINATION FilterType = 3 )
type FuzzyAnalyzerParameter ¶
type GetHttpClient ¶
type GetHttpClient func() IHttpClient
type GetRangeRequest ¶
type GetRangeRequest struct { RangeRowQueryCriteria *RangeRowQueryCriteria ExtraRequestInfo }
type GetRangeResponse ¶
type GetRangeResponse struct { Rows []*Row ConsumedCapacityUnit *ConsumedCapacityUnit NextStartPrimaryKey *PrimaryKey DataBlockType DataBlockType CompressType CompressType ResponseInfo }
type GetRowRequest ¶
type GetRowRequest struct { SingleRowQueryCriteria *SingleRowQueryCriteria ExtraRequestInfo }
type GetRowResponse ¶
type GetRowResponse struct { PrimaryKey PrimaryKey Columns []*AttributeColumn ConsumedCapacityUnit *ConsumedCapacityUnit ResponseInfo // contains filtered or unexported fields }
func (*GetRowResponse) GetColumnMap ¶
func (response *GetRowResponse) GetColumnMap() *ColumnMap
type GetShardIteratorRequest ¶
type GetShardIteratorRequest struct { StreamId *StreamId // required ShardId *ShardId // required Timestamp *int64 Token *string ExtraRequestInfo }
type GetShardIteratorResponse ¶
type GetShardIteratorResponse struct { ShardIterator *ShardIterator // required Token *string ResponseInfo }
type GetStreamRecordRequest ¶
type GetStreamRecordRequest struct { ShardIterator *ShardIterator // required Limit *int32 // optional. max records which will reside in response TableName *string ExtraRequestInfo }
type GetStreamRecordResponse ¶
type GetStreamRecordResponse struct { Records []*StreamRecord NextShardIterator *ShardIterator // optional. an indicator to be used to read more records in this shard CapacityUnit *ConsumedCapacityUnit MayMoreRecord *bool ResponseInfo }
type GetTimeseriesDataRequest ¶ added in v1.7.0
type GetTimeseriesDataRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewGetTimeseriesDataRequest ¶ added in v1.7.0
func NewGetTimeseriesDataRequest(timeseriesTableName string) *GetTimeseriesDataRequest
func (*GetTimeseriesDataRequest) AddFieldToGet ¶ added in v1.7.7
func (getDataRequest *GetTimeseriesDataRequest) AddFieldToGet(field *FieldToGet)
func (*GetTimeseriesDataRequest) GetBackward ¶ added in v1.7.7
func (getDataRequest *GetTimeseriesDataRequest) GetBackward() bool
func (*GetTimeseriesDataRequest) GetBeginTimeInUs ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetBeginTimeInUs() int64
func (*GetTimeseriesDataRequest) GetEndTimeInUs ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetEndTimeInUs() int64
func (*GetTimeseriesDataRequest) GetFieldsToGet ¶ added in v1.7.7
func (getDataRequest *GetTimeseriesDataRequest) GetFieldsToGet() []*FieldToGet
func (*GetTimeseriesDataRequest) GetLimit ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetLimit() int32
func (*GetTimeseriesDataRequest) GetNextToken ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetNextToken() []byte
func (*GetTimeseriesDataRequest) GetTimeRange ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetTimeRange() (int64, int64)
func (*GetTimeseriesDataRequest) GetTimeseriesKey ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetTimeseriesKey() *TimeseriesKey
func (*GetTimeseriesDataRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) GetTimeseriesTableName() string
func (*GetTimeseriesDataRequest) SetBackward ¶ added in v1.7.7
func (getDataRequest *GetTimeseriesDataRequest) SetBackward(backward bool)
func (*GetTimeseriesDataRequest) SetFieldsToGet ¶ added in v1.7.7
func (getDataRequest *GetTimeseriesDataRequest) SetFieldsToGet(fields []*FieldToGet)
func (*GetTimeseriesDataRequest) SetLimit ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) SetLimit(limit int32)
func (*GetTimeseriesDataRequest) SetNextToken ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) SetNextToken(nextToken []byte)
func (*GetTimeseriesDataRequest) SetTimeRange ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) SetTimeRange(beginTimeInUs int64, endTimeInUs int64)
func (*GetTimeseriesDataRequest) SetTimeseriesKey ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
func (*GetTimeseriesDataRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (getDataRequest *GetTimeseriesDataRequest) SetTimeseriesTableName(timeseriesTableName string)
type GetTimeseriesDataResponse ¶ added in v1.7.0
type GetTimeseriesDataResponse struct { ResponseInfo // contains filtered or unexported fields }
func CreateGetTimeseriesDataResponse ¶ added in v1.7.0
func CreateGetTimeseriesDataResponse(pbResponse *otsprotocol.GetTimeseriesDataResponse) (*GetTimeseriesDataResponse, error)
func (*GetTimeseriesDataResponse) GetNextToken ¶ added in v1.7.0
func (getTimeseriesDataResp *GetTimeseriesDataResponse) GetNextToken() []byte
func (*GetTimeseriesDataResponse) GetRows ¶ added in v1.7.0
func (getTimeseriesDataResp *GetTimeseriesDataResponse) GetRows() []*TimeseriesRow
type HTTPTimeout ¶
type HighlightField ¶ added in v1.7.9
type HighlightField struct {
Fragments []string
}
type HighlightResultItem ¶ added in v1.7.9
type HighlightResultItem struct {
HighlightFields map[string]*HighlightField
}
type IHttpClient ¶
use this to mock http.client for testing
type IndexMeta ¶
type IndexMeta struct { IndexName string Primarykey []string DefinedColumns []string IndexType IndexType IndexSyncPhase *SyncPhase }
func ConvertPbIndexMetaToIndexMeta ¶
func ConvertPbIndexMetaToIndexMeta(meta *otsprotocol.IndexMeta) *IndexMeta
func (*IndexMeta) AddDefinedColumn ¶
func (*IndexMeta) AddPrimaryKeyColumn ¶
func (*IndexMeta) ConvertToPbIndexMeta ¶
func (meta *IndexMeta) ConvertToPbIndexMeta() *otsprotocol.IndexMeta
func (*IndexMeta) SetAsGlobalIndex ¶
func (meta *IndexMeta) SetAsGlobalIndex()
func (*IndexMeta) SetAsLocalIndex ¶
func (meta *IndexMeta) SetAsLocalIndex()
type IndexOptions ¶
type IndexOptions int32
const ( IndexOptions_DOCS IndexOptions = 1 IndexOptions_FREQS IndexOptions = 2 IndexOptions_POSITIONS IndexOptions = 3 IndexOptions_OFFSETS IndexOptions = 4 )
type IndexSchema ¶
type IndexSchema struct { IndexSetting *IndexSetting FieldSchemas []*FieldSchema IndexSort *search.Sort }
func ParseFromPbSchema ¶ added in v1.7.3
func ParseFromPbSchema(pbSchema *otsprotocol.IndexSchema) (*IndexSchema, error)
type IndexSetting ¶
type IndexSetting struct {
RoutingFields []string
}
type IndexType ¶
type IndexType int32
func ConvertPbIndexTypeToIndexType ¶
func ConvertPbIndexTypeToIndexType(indexType *otsprotocol.IndexType) IndexType
type ListDeliveryTaskRequest ¶ added in v1.6.0
type ListDeliveryTaskRequest struct { TableName string ExtraRequestInfo }
type ListDeliveryTaskResponse ¶ added in v1.6.0
type ListDeliveryTaskResponse struct { Tasks []*DeliveryTaskInfo ResponseInfo }
type ListSearchIndexRequest ¶
type ListSearchIndexRequest struct { TableName string ExtraRequestInfo }
type ListSearchIndexResponse ¶
type ListSearchIndexResponse struct { IndexInfo []*IndexInfo ResponseInfo ResponseInfo }
type ListStreamRequest ¶
type ListStreamRequest struct { TableName *string ExtraRequestInfo }
type ListStreamResponse ¶
type ListStreamResponse struct { Streams []Stream ResponseInfo }
type ListTableResponse ¶
type ListTableResponse struct { TableNames []string ResponseInfo }
type ListTimeseriesTableRequest ¶ added in v1.7.0
type ListTimeseriesTableRequest struct {
ExtraRequestInfo
}
func NewListTimeseriesTableRequest ¶ added in v1.7.0
func NewListTimeseriesTableRequest() *ListTimeseriesTableRequest
type ListTimeseriesTableResponse ¶ added in v1.7.0
type ListTimeseriesTableResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*ListTimeseriesTableResponse) GetTimeseriesTableMeta ¶ added in v1.7.0
func (listTimeseriesTableResponse *ListTimeseriesTableResponse) GetTimeseriesTableMeta() []*TimeseriesTableMeta
func (*ListTimeseriesTableResponse) GetTimeseriesTableNames ¶ added in v1.7.0
func (listTimeseriesTableResponse *ListTimeseriesTableResponse) GetTimeseriesTableNames() []string
type LogicalOperator ¶
type LogicalOperator int32
const ( LO_NOT LogicalOperator = 1 LO_AND LogicalOperator = 2 LO_OR LogicalOperator = 3 )
func (*LogicalOperator) ConvertToPbLoType ¶
func (loType *LogicalOperator) ConvertToPbLoType() otsprotocol.LogicalOperator
type MeasurementMetaQueryCondition ¶ added in v1.7.0
type MeasurementMetaQueryCondition struct { Operator MetaQuerySingleOperator Value string }
func NewMeasurementQueryCondition ¶ added in v1.7.0
func NewMeasurementQueryCondition(operator MetaQuerySingleOperator, value string) *MeasurementMetaQueryCondition
func (*MeasurementMetaQueryCondition) GetType ¶ added in v1.7.0
func (measurementMetaQueryCondition *MeasurementMetaQueryCondition) GetType() MetaQueryConditionType
func (*MeasurementMetaQueryCondition) Serialize ¶ added in v1.7.0
func (measurementMetaQueryCondition *MeasurementMetaQueryCondition) Serialize() []byte
type MetaQueryCompositeOperator ¶ added in v1.7.0
type MetaQueryCompositeOperator int32
const ( OP_AND MetaQueryCompositeOperator = 1 OP_OR MetaQueryCompositeOperator = 2 OP_NOT MetaQueryCompositeOperator = 3 )
func ToMetaQueryCompositeOperator ¶ added in v1.7.3
func ToMetaQueryCompositeOperator(op string) (MetaQueryCompositeOperator, error)
func (*MetaQueryCompositeOperator) MarshalJSON ¶ added in v1.7.3
func (op *MetaQueryCompositeOperator) MarshalJSON() (data []byte, err error)
func (MetaQueryCompositeOperator) String ¶ added in v1.7.3
func (op MetaQueryCompositeOperator) String() string
func (*MetaQueryCompositeOperator) UnmarshalJSON ¶ added in v1.7.3
func (op *MetaQueryCompositeOperator) UnmarshalJSON(data []byte) (err error)
type MetaQueryCondition ¶ added in v1.7.0
type MetaQueryCondition interface { GetType() MetaQueryConditionType Serialize() []byte }
type MetaQueryConditionType ¶ added in v1.7.0
type MetaQueryConditionType int32
const ( COMPOSITE_CONDITION MetaQueryConditionType = 1 MEASUREMENT_CONDITION MetaQueryConditionType = 2 SOURCE_CONDITION MetaQueryConditionType = 3 TAG_CONDITION MetaQueryConditionType = 4 UPDATE_TIME_CONDITION MetaQueryConditionType = 5 ATTRIBUTE_CONDITION MetaQueryConditionType = 6 )
func ToMetaQueryConditionType ¶ added in v1.7.3
func ToMetaQueryConditionType(condType string) (MetaQueryConditionType, error)
func (*MetaQueryConditionType) MarshalJSON ¶ added in v1.7.3
func (op *MetaQueryConditionType) MarshalJSON() (data []byte, err error)
func (MetaQueryConditionType) String ¶ added in v1.7.3
func (condType MetaQueryConditionType) String() string
func (*MetaQueryConditionType) UnmarshalJSON ¶ added in v1.7.3
func (op *MetaQueryConditionType) UnmarshalJSON(data []byte) (err error)
type MetaQueryConditionWrapper ¶ added in v1.7.3
type MetaQueryConditionWrapper struct { Type MetaQueryConditionType QueryCondition MetaQueryCondition }
func (*MetaQueryConditionWrapper) UnmarshalJSON ¶ added in v1.7.3
func (op *MetaQueryConditionWrapper) UnmarshalJSON(data []byte) (err error)
type MetaQuerySingleOperator ¶ added in v1.7.0
type MetaQuerySingleOperator int32
const ( OP_EQUAL MetaQuerySingleOperator = 1 OP_GREATER_THAN MetaQuerySingleOperator = 2 OP_GREATER_EQUAL MetaQuerySingleOperator = 3 OP_LESS_THAN MetaQuerySingleOperator = 4 OP_LESS_EQUAL MetaQuerySingleOperator = 5 OP_PREFIX MetaQuerySingleOperator = 6 )
func ToMetaQuerySingleOperator ¶ added in v1.7.3
func ToMetaQuerySingleOperator(op string) (MetaQuerySingleOperator, error)
func (*MetaQuerySingleOperator) MarshalJSON ¶ added in v1.7.3
func (op *MetaQuerySingleOperator) MarshalJSON() (data []byte, err error)
func (MetaQuerySingleOperator) String ¶ added in v1.7.3
func (op MetaQuerySingleOperator) String() string
func (*MetaQuerySingleOperator) UnmarshalJSON ¶ added in v1.7.3
func (op *MetaQuerySingleOperator) UnmarshalJSON(data []byte) (err error)
type MeteringInfo ¶ added in v1.7.3
type MultiRowQueryCriteria ¶
type MultiRowQueryCriteria struct { PrimaryKey []*PrimaryKey ColumnsToGet []string TableName string MaxVersion int TimeRange *TimeRange Filter ColumnFilter StartColumn *string EndColumn *string }
func (*MultiRowQueryCriteria) AddColumnToGet ¶
func (rowQueryCriteria *MultiRowQueryCriteria) AddColumnToGet(columnName string)
func (*MultiRowQueryCriteria) AddRow ¶
func (rowQueryCriteria *MultiRowQueryCriteria) AddRow(pk *PrimaryKey)
func (*MultiRowQueryCriteria) SetFilter ¶
func (Criteria *MultiRowQueryCriteria) SetFilter(filter ColumnFilter)
type OSSTaskConfig ¶ added in v1.6.0
type OSSTaskConfig struct { OssPrefix string OssBucket string OssEndpoint string OssRoleName string EventTimeColumn *EventColumn Format Format Schema []*TaskSchema }
type PaginationFilter ¶
func (*PaginationFilter) Serialize ¶
func (pageFilter *PaginationFilter) Serialize() []byte
func (*PaginationFilter) ToFilter ¶
func (pageFilter *PaginationFilter) ToFilter() *otsprotocol.Filter
type ParallelScanRequest ¶ added in v1.6.0
type ParallelScanRequest struct { TableName string IndexName string ScanQuery search.ScanQuery ColumnsToGet *ColumnsToGet SessionId []byte TimeoutMs *int32 ExtraRequestInfo }
func (*ParallelScanRequest) ProtoBuffer ¶ added in v1.6.0
func (r *ParallelScanRequest) ProtoBuffer() (*otsprotocol.ParallelScanRequest, error)
func (*ParallelScanRequest) SetColumnsToGet ¶ added in v1.6.0
func (r *ParallelScanRequest) SetColumnsToGet(columnsToGet *ColumnsToGet) *ParallelScanRequest
func (*ParallelScanRequest) SetIndexName ¶ added in v1.6.0
func (r *ParallelScanRequest) SetIndexName(indexName string) *ParallelScanRequest
func (*ParallelScanRequest) SetScanQuery ¶ added in v1.6.0
func (r *ParallelScanRequest) SetScanQuery(scanQuery search.ScanQuery) *ParallelScanRequest
func (*ParallelScanRequest) SetSessionId ¶ added in v1.6.0
func (r *ParallelScanRequest) SetSessionId(sessionId []byte) *ParallelScanRequest
func (*ParallelScanRequest) SetTableName ¶ added in v1.6.0
func (r *ParallelScanRequest) SetTableName(tableName string) *ParallelScanRequest
func (*ParallelScanRequest) SetTimeoutMs ¶ added in v1.7.5
func (r *ParallelScanRequest) SetTimeoutMs(timeoutMs int32) *ParallelScanRequest
type ParallelScanResponse ¶ added in v1.6.0
type ParallelScanResponse struct { Rows []*Row NextToken []byte ResponseInfo }
type ParquetDataType ¶ added in v1.6.0
type ParquetDataType int32
const ( ParquetBool ParquetDataType = iota ParquetInt64 ParquetUtf8 ParquetDouble ParquetDate ParquetDecimal ParquetTimeMills ParquetTimeMicros ParquetTimestampMills ParquetTimestampMicros )
type PlainBufferCell ¶
type PlainBufferCell struct {
// contains filtered or unexported fields
}
type PlainBufferRow ¶
type PlainBufferRow struct {
// contains filtered or unexported fields
}
type PrimaryKey ¶
type PrimaryKey struct {
PrimaryKeys []*PrimaryKeyColumn
}
func (*PrimaryKey) AddPrimaryKeyColumn ¶
func (pk *PrimaryKey) AddPrimaryKeyColumn(primaryKeyName string, value interface{})
func (*PrimaryKey) AddPrimaryKeyColumnWithAutoIncrement ¶
func (pk *PrimaryKey) AddPrimaryKeyColumnWithAutoIncrement(primaryKeyName string)
func (*PrimaryKey) AddPrimaryKeyColumnWithMaxValue ¶
func (pk *PrimaryKey) AddPrimaryKeyColumnWithMaxValue(primaryKeyName string)
Only used for range query
func (*PrimaryKey) AddPrimaryKeyColumnWithMinValue ¶
func (pk *PrimaryKey) AddPrimaryKeyColumnWithMinValue(primaryKeyName string)
func (*PrimaryKey) Build ¶
func (pk *PrimaryKey) Build(isDelete bool) []byte
type PrimaryKey2 ¶
type PrimaryKey2 struct {
// contains filtered or unexported fields
}
type PrimaryKeyColumn ¶
type PrimaryKeyColumn struct { ColumnName string Value interface{} PrimaryKeyOption PrimaryKeyOption }
func (*PrimaryKeyColumn) String ¶
func (this *PrimaryKeyColumn) String() string
type PrimaryKeyColumnInner ¶
type PrimaryKeyColumnInner struct { Name []byte Type otsprotocol.PrimaryKeyType Value interface{} }
func NewPrimaryKeyColumn ¶
func NewPrimaryKeyColumn(name []byte, value interface{}, option PrimaryKeyOption) *PrimaryKeyColumnInner
func NewPrimaryKeyColumnAuto_Increment ¶
func NewPrimaryKeyColumnAuto_Increment(name []byte) *PrimaryKeyColumnInner
func NewPrimaryKeyColumnINF_MAX ¶
func NewPrimaryKeyColumnINF_MAX(name []byte) *PrimaryKeyColumnInner
func NewPrimaryKeyColumnINF_MIN ¶
func NewPrimaryKeyColumnINF_MIN(name []byte) *PrimaryKeyColumnInner
type PrimaryKeyOption ¶
type PrimaryKeyOption int32
const ( NONE PrimaryKeyOption = 0 AUTO_INCREMENT PrimaryKeyOption = 1 MIN PrimaryKeyOption = 2 MAX PrimaryKeyOption = 3 )
type PrimaryKeySchema ¶
type PrimaryKeySchema struct { Name *string Type *PrimaryKeyType Option *PrimaryKeyOption }
type PrimaryKeyType ¶
type PrimaryKeyType int32
const ( PrimaryKeyType_INTEGER PrimaryKeyType = 1 PrimaryKeyType_STRING PrimaryKeyType = 2 PrimaryKeyType_BINARY PrimaryKeyType = 3 )
type PutRowChange ¶
type PutRowChange struct { TableName string PrimaryKey *PrimaryKey Columns []AttributeColumn Condition *RowCondition ReturnType ReturnType TransactionId *string }
func (*PutRowChange) AddColumn ¶
func (rowchange *PutRowChange) AddColumn(columnName string, value interface{})
value only support int64,string,bool,float64,[]byte. other type will get panic
func (*PutRowChange) AddColumnWithTimestamp ¶
func (rowchange *PutRowChange) AddColumnWithTimestamp(columnName string, value interface{}, timestamp int64)
value only support int64,string,bool,float64,[]byte. other type will get panic
func (*PutRowChange) GetTableName ¶
func (rowchange *PutRowChange) GetTableName() string
func (*PutRowChange) Serialize ¶
func (rowchange *PutRowChange) Serialize() []byte
func (*PutRowChange) SetColumnCondition ¶
func (rowchange *PutRowChange) SetColumnCondition(condition ColumnFilter)
func (*PutRowChange) SetCondition ¶
func (rowchange *PutRowChange) SetCondition(rowExistenceExpectation RowExistenceExpectation)
func (*PutRowChange) SetReturnPk ¶
func (rowchange *PutRowChange) SetReturnPk()
type PutRowRequest ¶
type PutRowRequest struct { PutRowChange *PutRowChange ExtraRequestInfo }
type PutRowResponse ¶
type PutRowResponse struct { ConsumedCapacityUnit *ConsumedCapacityUnit PrimaryKey PrimaryKey ResponseInfo }
type PutTimeseriesDataRequest ¶ added in v1.7.0
type PutTimeseriesDataRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewPutTimeseriesDataRequest ¶ added in v1.7.0
func NewPutTimeseriesDataRequest(timeseriesTableName string) *PutTimeseriesDataRequest
func (*PutTimeseriesDataRequest) AddTimeseriesRows ¶ added in v1.7.0
func (putTimeseriesDataRequest *PutTimeseriesDataRequest) AddTimeseriesRows(timeseriesRows ...*TimeseriesRow)
func (*PutTimeseriesDataRequest) GetTimeseriesRows ¶ added in v1.7.0
func (putTimeseriesDataRequest *PutTimeseriesDataRequest) GetTimeseriesRows() []*TimeseriesRow
func (*PutTimeseriesDataRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (putTimeseriesDataRequest *PutTimeseriesDataRequest) GetTimeseriesTableName() string
func (*PutTimeseriesDataRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (putTimeseriesDataRequest *PutTimeseriesDataRequest) SetTimeseriesTableName(timeseriesTableName string)
type PutTimeseriesDataResponse ¶ added in v1.7.0
type PutTimeseriesDataResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*PutTimeseriesDataResponse) GetFailedRowResults ¶ added in v1.7.0
func (putTimeseriesDataResponse *PutTimeseriesDataResponse) GetFailedRowResults() []*FailedRowResult
type QueryFlowWeight ¶ added in v1.7.4
func (*QueryFlowWeight) String ¶ added in v1.7.4
func (queryFlowWeight *QueryFlowWeight) String() string
type QueryTimeseriesMetaRequest ¶ added in v1.7.0
type QueryTimeseriesMetaRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewQueryTimeseriesMetaRequest ¶ added in v1.7.0
func NewQueryTimeseriesMetaRequest(timeseriesTableName string) *QueryTimeseriesMetaRequest
func (*QueryTimeseriesMetaRequest) GetCondition ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetCondition() MetaQueryCondition
func (*QueryTimeseriesMetaRequest) GetLimit ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetLimit() int32
func (*QueryTimeseriesMetaRequest) GetNextToken ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetNextToken() []byte
func (*QueryTimeseriesMetaRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetTimeseriesTableName() string
func (*QueryTimeseriesMetaRequest) GetTotalHits ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) GetTotalHits() bool
func (*QueryTimeseriesMetaRequest) SetCondition ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetCondition(condition MetaQueryCondition)
func (*QueryTimeseriesMetaRequest) SetLimit ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetLimit(limit int32)
func (*QueryTimeseriesMetaRequest) SetNextToken ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetNextToken(nextToken []byte)
func (*QueryTimeseriesMetaRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
func (*QueryTimeseriesMetaRequest) SetTotalHits ¶ added in v1.7.0
func (queryTimeseriesMetaRequest *QueryTimeseriesMetaRequest) SetTotalHits(getTotalHits bool)
type QueryTimeseriesMetaResponse ¶ added in v1.7.0
type QueryTimeseriesMetaResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*QueryTimeseriesMetaResponse) GetNextToken ¶ added in v1.7.0
func (queryTimeseriesMetaResponse *QueryTimeseriesMetaResponse) GetNextToken() []byte
func (*QueryTimeseriesMetaResponse) GetTimeseriesMetas ¶ added in v1.7.0
func (queryTimeseriesMetaResponse *QueryTimeseriesMetaResponse) GetTimeseriesMetas() []*TimeseriesMeta
func (*QueryTimeseriesMetaResponse) GetTotalHits ¶ added in v1.7.0
func (queryTimeseriesMetaResponse *QueryTimeseriesMetaResponse) GetTotalHits() int64
type RangeRowQueryCriteria ¶
type RangeRowQueryCriteria struct { TableName string StartPrimaryKey *PrimaryKey EndPrimaryKey *PrimaryKey ColumnsToGet []string MaxVersion int32 TimeRange *TimeRange Filter ColumnFilter Direction Direction Limit int32 StartColumn *string EndColumn *string TransactionId *string // DataBlockType指定对服务器端返回的数据编码格式,未设置相当于DataBlockType.PLAIN_BUFFER. DataBlockType DataBlockType // 当columnsToGet不为空,且不包含所有主键列时,ReturnSpecifiedPkOnly为false时会返回全部主键列, // 若为true,则只返回columnsToGet中指定的主键列. ReturnSpecifiedPkOnly bool // CompressType指定服务端返回的数据的压缩类型,未设置相当于CompressType.NONE. CompressType CompressType }
func (*RangeRowQueryCriteria) AddColumnToGet ¶
func (rowQueryCriteria *RangeRowQueryCriteria) AddColumnToGet(columnName string)
type RecordColumn ¶
type RecordColumn struct { Type RecordColumnType Name *string // required Value interface{} // optional. present when Type is RCT_Put Timestamp *int64 // optional, in msec. present when Type is RCT_Put or RCT_DeleteOneVersion }
func (*RecordColumn) String ¶
func (this *RecordColumn) String() string
type RecordColumnType ¶
type RecordColumnType int
const ( RCT_Put RecordColumnType = iota RCT_DeleteOneVersion RCT_DeleteAllVersions )
type RecordSequenceInfo ¶
func (*RecordSequenceInfo) String ¶
func (this *RecordSequenceInfo) String() string
type RequestExtension ¶ added in v1.7.12
type RequestExtension struct {
// contains filtered or unexported fields
}
func (*RequestExtension) SetPriority ¶ added in v1.7.12
func (re *RequestExtension) SetPriority(priority Priority)
func (*RequestExtension) SetTag ¶ added in v1.7.12
func (re *RequestExtension) SetTag(tag string)
type ReservedThroughput ¶
type ReservedThroughput struct {
Readcap, Writecap int
}
type ResponseInfo ¶
type ResponseInfo struct {
RequestId string
}
type RetryNotify ¶ added in v1.7.11
type ReturnType ¶
type ReturnType int32
const ( ReturnType_RT_NONE ReturnType = 0 ReturnType_RT_PK ReturnType = 1 ReturnType_RT_AFTER_MODIFY ReturnType = 2 )
type Row ¶
type Row struct { PrimaryKey *PrimaryKey Columns []*AttributeColumn }
type RowCondition ¶
type RowCondition struct { RowExistenceExpectation RowExistenceExpectation ColumnCondition ColumnFilter }
type RowExistenceExpectation ¶
type RowExistenceExpectation int
const ( RowExistenceExpectation_IGNORE RowExistenceExpectation = 0 RowExistenceExpectation_EXPECT_EXIST RowExistenceExpectation = 1 RowExistenceExpectation_EXPECT_NOT_EXIST RowExistenceExpectation = 2 )
type RowPutChange ¶
type RowPutChange struct {
// contains filtered or unexported fields
}
func (*RowPutChange) Build ¶
func (rpc *RowPutChange) Build() []byte
type RowResult ¶
type RowResult struct { TableName string IsSucceed bool Error Error PrimaryKey PrimaryKey Columns []*AttributeColumn ConsumedCapacityUnit *ConsumedCapacityUnit Index int32 }
type RowUpdateChange ¶
type RowUpdateChange struct {
// contains filtered or unexported fields
}
func (*RowUpdateChange) Build ¶
func (ruc *RowUpdateChange) Build() []byte
type SQLColumnInfo ¶ added in v1.7.3
type SQLColumnInfo struct { Name string Type ColumnType // contains filtered or unexported fields }
SQLColumnInfo contains information of a column.
func (*SQLColumnInfo) String ¶ added in v1.7.7
func (column *SQLColumnInfo) String() string
type SQLPayloadVersion ¶ added in v1.7.3
type SQLPayloadVersion int32
const ( SQLPAYLOAD_PLAIN_BUFFER SQLPayloadVersion = 1 SQLPAYLOAD_FLAT_BUFFERS SQLPayloadVersion = 2 )
type SQLQueryConsumed ¶ added in v1.7.4
type SQLQueryConsumed struct { SearchConsumes []*SearchConsumedCU TableConsumes []*TableConsumedCU }
type SQLQueryRequest ¶ added in v1.7.0
type SQLQueryRequest struct { Query string SearchToken *string ExtraRequestInfo }
func (*SQLQueryRequest) SetSearchToken ¶ added in v1.7.15
func (s *SQLQueryRequest) SetSearchToken(searchToken *string) *SQLQueryRequest
type SQLQueryResponse ¶ added in v1.7.0
type SQLQueryResponse struct { ResultSet SQLResultSet StmtType SQLStatementType PayloadVersion SQLPayloadVersion SQLQueryConsumed *SQLQueryConsumed NextSearchToken *string ResponseInfo }
type SQLResultSet ¶ added in v1.7.3
type SQLResultSet interface { // Columns returns the column infos of SQLResultSet. Columns() []*SQLColumnInfo // Next returns the next row of SQLResultSet. Next() SQLRow // HasNext returns whether finished. HasNext() bool // Reset reset the cursor to beginning. Reset() }
SQLResultSet is the result of a sql query. Its cursor starts before the first row of the result set. Use Next to fetch next row.
func NewSQLResultSetFromFlatBuffers ¶ added in v1.7.8
func NewSQLResultSetFromFlatBuffers(rowBytes []byte) (SQLResultSet, error)
func NewSQLResultSetFromPlainBuffer ¶ added in v1.7.8
func NewSQLResultSetFromPlainBuffer(rowBytes []byte) (SQLResultSet, error)
type SQLRow ¶ added in v1.7.3
type SQLRow interface { // IsNull returns whether the value with the colIdx is nil. // When return true, means <code>NULL</code> in SQL. IsNull(colIdx int) (bool, error) // IsNullByName returns whether the value with the column name is nil. // When return true, means <code>NULL</code> in SQL. IsNullByName(colName string) (bool, error) // GetString returns the string value with the colIdx. // if the value is SQL <code>NULL</code>, the value returned is <code>""</code GetString(colIdx int) (string, error) // GetStringByName returns the string value with the column Name. GetStringByName(colName string) (string, error) // GetInt64 returns the int64 value with the colIdx. // if the value is SQL <code>NULL</code>, the value returned is <code>0</code> GetInt64(colIdx int) (int64, error) // GetInt64ByName returns the int64 value with the column Name. GetInt64ByName(colName string) (int64, error) // GetBool returns the bool value with the colIdx. // if the value is SQL <code>NULL</code>, the value returned is <code>false</code> GetBool(colIdx int) (bool, error) // GetBoolByName returns the bool value with the column Name. GetBoolByName(colName string) (bool, error) // GetBytes returns the bytes value with the colIdx. // if the value is SQL <code>NULL</code>, the value returned is <code>nil</code> GetBytes(colIdx int) ([]byte, error) // GetBytesByName returns the bytes value with the column Name. GetBytesByName(colName string) ([]byte, error) // GetFloat64 returns the float64 value with the colIdx. // if the value is SQL <code>NULL</code>, the value returned is <code>0</code> GetFloat64(colIdx int) (float64, error) // GetFloat64ByName returns the float64 value with the column Name. GetFloat64ByName(colName string) (float64, error) // GetTime returns the time.Duration with the colIdx. GetTime(colIdx int) (time.Duration, error) // GetTimeByName returns the time.Duration with the column Name. GetTimeByName(colName string) (time.Duration, error) // GetDateTime returns the time.Time with the colIdx. GetDateTime(colIdx int) (time.Time, error) // GetDateTimeByName returns the time.Time with the column Name. GetDateTimeByName(colName string) (time.Time, error) // GetDate returns the time.Time with the colIdx. GetDate(colIdx int) (time.Time, error) // GetDateByName returns the time.Time with the column Name. GetDateByName(colName string) (time.Time, error) // DebugString for debug/test/print use DebugString() string }
SQLRow represents a row of data, can be used to access values.
type SQLStatementType ¶ added in v1.7.3
type SQLStatementType int32
const ( SQL_SELECT SQLStatementType = 1 SQL_CREATE_TABLE SQLStatementType = 2 SQL_SHOW_TABLE SQLStatementType = 3 SQL_DESCRIBE_TABLE SQLStatementType = 4 SQL_DROP_TABLE SQLStatementType = 5 SQL_ALTER_TABLE SQLStatementType = 6 )
func (*SQLStatementType) String ¶ added in v1.7.7
func (t *SQLStatementType) String() string
type SQLTableMeta ¶ added in v1.7.3
type SQLTableMeta struct {
// contains filtered or unexported fields
}
type SSEDetails ¶ added in v1.7.6
type SSEDetails struct { // 是否开启服务器端加密 Enable bool // 秘钥类型, 开启服务器端加密时有效 KeyType SSEKeyType // 主密钥在KMS中的id, 可以根据keyId在KMS系统中对秘钥的使用情况进行审计 // 开启服务器端加密时有效 KeyId string // 授权表格存储临时访问KMS用户主密钥的全局资源描述符 // 开启服务器端加密且秘钥类型为SSE_BYOK时有效 RoleArn string }
type SSEKeyType ¶ added in v1.7.6
type SSEKeyType int
表示服务器端加密的秘钥类型
const ( // 使用KMS的服务主密钥 SSE_KMS_SERVICE SSEKeyType = iota // 使用KMS的用户主密钥,支持用户自定义秘钥上传 SSE_BYOK )
func (*SSEKeyType) String ¶ added in v1.7.6
func (t *SSEKeyType) String() string
type SSESpecification ¶ added in v1.7.6
type SSESpecification struct { // 是否开启服务器端加密 Enable bool // 当开启服务器端加密时,该参数用于设置秘钥类型 KeyType *SSEKeyType // 当开启服务器端加密且秘钥类型为BYOK时,该参数用于指定KMS用户主密钥的id KeyId *string // 当开启服务器端加密且秘钥类型为BYOK时,需要通过STS服务授权表格存储获取临时访问令牌访问传入的KMS用户主密钥, // 该参数用于指定为此创建的RAM角色的全局资源描述符 RoleArn *string }
func (*SSESpecification) CheckArguments ¶ added in v1.7.6
func (sse *SSESpecification) CheckArguments() error
func (*SSESpecification) SetEnable ¶ added in v1.7.6
func (sse *SSESpecification) SetEnable(enable bool)
func (*SSESpecification) SetKeyId ¶ added in v1.7.6
func (sse *SSESpecification) SetKeyId(keyId string)
func (*SSESpecification) SetKeyType ¶ added in v1.7.6
func (sse *SSESpecification) SetKeyType(keyType SSEKeyType)
func (*SSESpecification) SetRoleArn ¶ added in v1.7.6
func (sse *SSESpecification) SetRoleArn(roleArn string)
type SearchConsumedCU ¶ added in v1.7.4
type SearchConsumedCU struct { TableName string IndexName string ConsumedCapacityUnit *ConsumedCapacityUnit }
type SearchHit ¶ added in v1.7.9
type SearchHit struct { Row *Row Score *float64 NestedDocOffset *int32 HighlightResultItem *HighlightResultItem SearchInnerHits map[string]*SearchInnerHit }
type SearchIndexSplitsOptions ¶ added in v1.6.0
type SearchIndexSplitsOptions struct {
IndexName string
}
compute splits
type SearchInnerHit ¶ added in v1.7.12
type SearchRequest ¶
type SearchRequest struct { TableName string IndexName string SearchQuery search.SearchQuery ColumnsToGet *ColumnsToGet RoutingValues []*PrimaryKey TimeoutMs *int32 ExtraRequestInfo }
func (*SearchRequest) AddRoutingValue ¶
func (r *SearchRequest) AddRoutingValue(routingValue *PrimaryKey) *SearchRequest
func (*SearchRequest) ProtoBuffer ¶
func (r *SearchRequest) ProtoBuffer() (*otsprotocol.SearchRequest, error)
func (*SearchRequest) SetColumnsToGet ¶
func (r *SearchRequest) SetColumnsToGet(columnToGet *ColumnsToGet) *SearchRequest
func (*SearchRequest) SetIndexName ¶
func (r *SearchRequest) SetIndexName(indexName string) *SearchRequest
func (*SearchRequest) SetRoutingValues ¶
func (r *SearchRequest) SetRoutingValues(routingValues []*PrimaryKey) *SearchRequest
func (*SearchRequest) SetSearchQuery ¶
func (r *SearchRequest) SetSearchQuery(searchQuery search.SearchQuery) *SearchRequest
func (*SearchRequest) SetTableName ¶
func (r *SearchRequest) SetTableName(tableName string) *SearchRequest
func (*SearchRequest) SetTimeoutMs ¶ added in v1.7.5
func (r *SearchRequest) SetTimeoutMs(timeoutMs int32) *SearchRequest
type SearchResponse ¶
type SearchResponse struct { TotalCount int64 Rows []*Row SearchHits []*SearchHit IsAllSuccess bool NextToken []byte AggregationResults search.AggregationResults GroupByResults search.GroupByResults ConsumedCapacityUnit *ConsumedCapacityUnit ReservedThroughput *ReservedThroughput ResponseInfo }
type ShardIterator ¶
type ShardIterator string
type SingleColumnCondition ¶
type SingleColumnCondition struct { Comparator *ComparatorType ColumnName *string ColumnValue interface{} //[]byte FilterIfMissing bool LatestVersionOnly bool TransferRule *ValueTransferRule }
func NewSingleColumnCondition ¶
func NewSingleColumnCondition(columnName string, comparator ComparatorType, value interface{}) *SingleColumnCondition
func NewSingleColumnValueRegexFilter ¶
func NewSingleColumnValueRegexFilter(columnName string, comparator ComparatorType, rule *ValueTransferRule, value interface{}) *SingleColumnCondition
func (*SingleColumnCondition) Serialize ¶
func (condition *SingleColumnCondition) Serialize() []byte
func (*SingleColumnCondition) ToFilter ¶
func (condition *SingleColumnCondition) ToFilter() *otsprotocol.Filter
type SingleRowQueryCriteria ¶
type SingleRowQueryCriteria struct { ColumnsToGet []string TableName string PrimaryKey *PrimaryKey MaxVersion int32 TimeRange *TimeRange Filter ColumnFilter StartColumn *string EndColumn *string TransactionId *string }
func (*SingleRowQueryCriteria) AddColumnToGet ¶
func (rowQueryCriteria *SingleRowQueryCriteria) AddColumnToGet(columnName string)
func (*SingleRowQueryCriteria) SetEndtColumn ¶
func (rowQueryCriteria *SingleRowQueryCriteria) SetEndtColumn(columnName string)
func (*SingleRowQueryCriteria) SetFilter ¶
func (Criteria *SingleRowQueryCriteria) SetFilter(filter ColumnFilter)
func (*SingleRowQueryCriteria) SetStartColumn ¶
func (rowQueryCriteria *SingleRowQueryCriteria) SetStartColumn(columnName string)
type Split ¶
type Split struct { LowerBound *PrimaryKey UpperBound *PrimaryKey Location string }
type SplitAnalyzerParameter ¶
type SplitAnalyzerParameter struct {
Delimiter *string
}
type StartLocalTransactionRequest ¶
type StartLocalTransactionRequest struct { PrimaryKey *PrimaryKey TableName string ExtraRequestInfo }
type StartLocalTransactionResponse ¶
type StartLocalTransactionResponse struct { TransactionId *string ResponseInfo }
type StreamDetails ¶
type StreamRecord ¶
type StreamRecord struct { Type ActionType Info *RecordSequenceInfo // required PrimaryKey *PrimaryKey // required Columns []*RecordColumn OriginColumns []*RecordColumn }
func (*StreamRecord) String ¶
func (this *StreamRecord) String() string
type StreamShard ¶
type StreamShard struct { SelfShard *ShardId // required FatherShard *ShardId // optional MotherShard *ShardId // optional }
* Shards are possibly splitted into two or merged from two. * After splitting, both newly generated shards have the same FatherShard. * After merging, the newly generated shard have both FatherShard and MotherShard.
type StreamSpecification ¶
type TableConsumedCU ¶ added in v1.7.4
type TableConsumedCU struct { TableName string ConsumedCapacityUnit *ConsumedCapacityUnit }
type TableMeta ¶
type TableMeta struct { TableName string SchemaEntry []*PrimaryKeySchema DefinedColumns []*DefinedColumnSchema }
func (*TableMeta) AddDefinedColumn ¶
func (meta *TableMeta) AddDefinedColumn(name string, definedType DefinedColumnType)
func (*TableMeta) AddPrimaryKeyColumn ¶
func (meta *TableMeta) AddPrimaryKeyColumn(name string, keyType PrimaryKeyType)
func (*TableMeta) AddPrimaryKeyColumnOption ¶
func (meta *TableMeta) AddPrimaryKeyColumnOption(name string, keyType PrimaryKeyType, keyOption PrimaryKeyOption)
type TableOption ¶
type TableOption struct {
TimeToAlive, MaxVersion int
DeviationCellVersionInSec int64
AllowUpdate *bool
UpdateFullRow *bool // generally, this option can not be updated
}
func NewTableOption ¶
func NewTableOption(timeToAlive int, maxVersion int) *TableOption
func NewTableOptionWithMaxVersion ¶
func NewTableOptionWithMaxVersion(maxVersion int) *TableOption
type TableStoreApi ¶
type TableStoreApi interface { CreateTable(request *CreateTableRequest) (*CreateTableResponse, error) ListTable() (*ListTableResponse, error) DeleteTable(request *DeleteTableRequest) (*DeleteTableResponse, error) DescribeTable(request *DescribeTableRequest) (*DescribeTableResponse, error) UpdateTable(request *UpdateTableRequest) (*UpdateTableResponse, error) PutRow(request *PutRowRequest) (*PutRowResponse, error) DeleteRow(request *DeleteRowRequest) (*DeleteRowResponse, error) GetRow(request *GetRowRequest) (*GetRowResponse, error) UpdateRow(request *UpdateRowRequest) (*UpdateRowResponse, error) BatchGetRow(request *BatchGetRowRequest) (*BatchGetRowResponse, error) BatchWriteRow(request *BatchWriteRowRequest) (*BatchWriteRowResponse, error) GetRange(request *GetRangeRequest) (*GetRangeResponse, error) // stream related ListStream(request *ListStreamRequest) (*ListStreamResponse, error) DescribeStream(request *DescribeStreamRequest) (*DescribeStreamResponse, error) GetShardIterator(request *GetShardIteratorRequest) (*GetShardIteratorResponse, error) GetStreamRecord(request *GetStreamRecordRequest) (*GetStreamRecordResponse, error) // search related CreateSearchIndex(request *CreateSearchIndexRequest) (*CreateSearchIndexResponse, error) UpdateSearchIndex(request *UpdateSearchIndexRequest) (*UpdateSearchIndexResponse, error) DeleteSearchIndex(request *DeleteSearchIndexRequest) (*DeleteSearchIndexResponse, error) ListSearchIndex(request *ListSearchIndexRequest) (*ListSearchIndexResponse, error) DescribeSearchIndex(request *DescribeSearchIndexRequest) (*DescribeSearchIndexResponse, error) Search(request *SearchRequest) (*SearchResponse, error) ComputeSplits(request *ComputeSplitsRequest) (*ComputeSplitsResponse, error) ParallelScan(request *ParallelScanRequest) (*ParallelScanResponse, error) SQLQuery(req *SQLQueryRequest) (*SQLQueryResponse, error) }
type TableStoreClient ¶
type TableStoreClient struct {
// contains filtered or unexported fields
}
@class TableStoreClient The TableStoreClient, which will connect OTS service for authorization, create/list/ delete tables/table groups, to get/put/delete a row. Note: TableStoreClient is thread-safe. TableStoreClient的功能包括连接OTS服务进行验证、创建/列出/删除表或表组、插入/获取/ 删除/更新行数据
func NewClient ¶
func NewClient(endPoint, instanceName, accessKeyId, accessKeySecret string, options ...ClientOption) *TableStoreClient
Constructor: to create the client of TableStore service. 构造函数:创建表格存储服务的客户端。
@param endPoint The address of TableStore service. 表格存储服务地址。 @param instanceName @param accessId The Access ID. 用于标示用户的ID。 @param accessKey The Access Key. 用于签名和验证的密钥。 @param options set client config
func NewClientWithConfig ¶
func NewClientWithConfig(endPoint, instanceName, accessKeyId, accessKeySecret string, securityToken string, config *TableStoreConfig, options ...ClientOption) *TableStoreClient
Constructor: to create the client of OTS service. 传入config 构造函数:创建OTS服务的客户端。
func NewClientWithExternalHeader ¶
func NewClientWithExternalHeader(endPoint, instanceName, accessKeyId, accessKeySecret string, securityToken string, config *TableStoreConfig, header map[string]string) *TableStoreClient
func (*TableStoreClient) AbortTransaction ¶
func (client *TableStoreClient) AbortTransaction(request *AbortTransactionRequest) (*AbortTransactionResponse, error)
func (*TableStoreClient) AddDefinedColumn ¶
func (tableStoreClient *TableStoreClient) AddDefinedColumn(request *AddDefinedColumnRequest) (*AddDefinedColumnResponse, error)
func (*TableStoreClient) BatchGetRow ¶
func (tableStoreClient *TableStoreClient) BatchGetRow(request *BatchGetRowRequest) (*BatchGetRowResponse, error)
Batch Get Row @param BatchGetRowRequest
func (*TableStoreClient) BatchWriteRow ¶
func (tableStoreClient *TableStoreClient) BatchWriteRow(request *BatchWriteRowRequest) (*BatchWriteRowResponse, error)
Batch Write Row @param BatchWriteRowRequest
func (*TableStoreClient) CommitTransaction ¶
func (client *TableStoreClient) CommitTransaction(request *CommitTransactionRequest) (*CommitTransactionResponse, error)
func (TableStoreClient) ComputeSplitPointsBySize ¶
func (client TableStoreClient) ComputeSplitPointsBySize(req *ComputeSplitPointsBySizeRequest) (*ComputeSplitPointsBySizeResponse, error)
func (*TableStoreClient) ComputeSplits ¶ added in v1.6.0
func (client *TableStoreClient) ComputeSplits(request *ComputeSplitsRequest) (*ComputeSplitsResponse, error)
func (*TableStoreClient) CreateDeliveryTask ¶ added in v1.6.0
func (client *TableStoreClient) CreateDeliveryTask(request *CreateDeliveryTaskRequest) (*CreateDeliveryTaskResponse, error)
func (*TableStoreClient) CreateIndex ¶
func (tableStoreClient *TableStoreClient) CreateIndex(request *CreateIndexRequest) (*CreateIndexResponse, error)
func (*TableStoreClient) CreateSearchIndex ¶
func (tableStoreClient *TableStoreClient) CreateSearchIndex(request *CreateSearchIndexRequest) (*CreateSearchIndexResponse, error)
func (*TableStoreClient) CreateTable ¶
func (tableStoreClient *TableStoreClient) CreateTable(request *CreateTableRequest) (*CreateTableResponse, error)
table API Create a table with the CreateTableRequest, in which the table name and primary keys are required. 根据CreateTableRequest创建一个表,其中表名和主健列是必选项
@param request of CreateTableRequest. @return Void. 无返回值。
func (*TableStoreClient) DeleteDefinedColumn ¶
func (tableStoreClient *TableStoreClient) DeleteDefinedColumn(request *DeleteDefinedColumnRequest) (*DeleteDefinedColumnResponse, error)
func (*TableStoreClient) DeleteDeliveryTask ¶ added in v1.6.0
func (client *TableStoreClient) DeleteDeliveryTask(request *DeleteDeliveryTaskRequest) (*DeleteDeliveryTaskResponse, error)
func (*TableStoreClient) DeleteIndex ¶
func (tableStoreClient *TableStoreClient) DeleteIndex(request *DeleteIndexRequest) (*DeleteIndexResponse, error)
func (*TableStoreClient) DeleteRow ¶
func (tableStoreClient *TableStoreClient) DeleteRow(request *DeleteRowRequest) (*DeleteRowResponse, error)
Delete row with pk @param DeleteRowRequest
func (*TableStoreClient) DeleteSearchIndex ¶
func (tableStoreClient *TableStoreClient) DeleteSearchIndex(request *DeleteSearchIndexRequest) (*DeleteSearchIndexResponse, error)
func (*TableStoreClient) DeleteTable ¶
func (tableStoreClient *TableStoreClient) DeleteTable(request *DeleteTableRequest) (*DeleteTableResponse, error)
Delete a table and all its views will be deleted. 删除一个表
@param tableName The table name. 表名。 @return Void. 无返回值。
func (*TableStoreClient) DescribeDeliveryTask ¶ added in v1.6.0
func (client *TableStoreClient) DescribeDeliveryTask(request *DescribeDeliveryTaskRequest) (*DescribeDeliveryTaskResponse, error)
func (*TableStoreClient) DescribeSearchIndex ¶
func (tableStoreClient *TableStoreClient) DescribeSearchIndex(request *DescribeSearchIndexRequest) (*DescribeSearchIndexResponse, error)
func (*TableStoreClient) DescribeStream ¶
func (client *TableStoreClient) DescribeStream(req *DescribeStreamRequest) (*DescribeStreamResponse, error)
func (*TableStoreClient) DescribeTable ¶
func (tableStoreClient *TableStoreClient) DescribeTable(request *DescribeTableRequest) (*DescribeTableResponse, error)
Query the tablemeta, tableoption and reservedthroughtputdetails @param DescribeTableRequest @param DescribeTableResponse
func (*TableStoreClient) GetExternalHeader ¶ added in v1.7.0
func (tableStoreClient *TableStoreClient) GetExternalHeader() map[string]string
func (*TableStoreClient) GetRange ¶
func (tableStoreClient *TableStoreClient) GetRange(request *GetRangeRequest) (*GetRangeResponse, error)
Get Range @param GetRangeRequest
func (*TableStoreClient) GetRetryNotify ¶ added in v1.7.11
func (tableStoreClient *TableStoreClient) GetRetryNotify() RetryNotify
func (*TableStoreClient) GetRow ¶
func (tableStoreClient *TableStoreClient) GetRow(request *GetRowRequest) (*GetRowResponse, error)
row API Get the data of a row or some columns.
@param getrowrequest
func (*TableStoreClient) GetShardIterator ¶
func (client *TableStoreClient) GetShardIterator(req *GetShardIteratorRequest) (*GetShardIteratorResponse, error)
func (TableStoreClient) GetStreamRecord ¶
func (client TableStoreClient) GetStreamRecord(req *GetStreamRecordRequest) (*GetStreamRecordResponse, error)
func (*TableStoreClient) ListDeliveryTask ¶ added in v1.6.0
func (client *TableStoreClient) ListDeliveryTask(request *ListDeliveryTaskRequest) (*ListDeliveryTaskResponse, error)
func (*TableStoreClient) ListSearchIndex ¶
func (tableStoreClient *TableStoreClient) ListSearchIndex(request *ListSearchIndexRequest) (*ListSearchIndexResponse, error)
func (*TableStoreClient) ListStream ¶
func (client *TableStoreClient) ListStream(req *ListStreamRequest) (*ListStreamResponse, error)
func (*TableStoreClient) ListTable ¶
func (tableStoreClient *TableStoreClient) ListTable() (*ListTableResponse, error)
List all tables. If done, all table names will be returned. 列出所有的表,如果操作成功,将返回所有表的名称。
@param tableNames The returned table names. 返回的表名集合。 @return Void. 无返回值。
func (*TableStoreClient) ParallelScan ¶ added in v1.6.0
func (TableStoreClient *TableStoreClient) ParallelScan(request *ParallelScanRequest) (*ParallelScanResponse, error)
func (*TableStoreClient) PutRow ¶
func (tableStoreClient *TableStoreClient) PutRow(request *PutRowRequest) (*PutRowResponse, error)
Put or update a row in a table. The operation is determined by CheckingType, which has three options: NO, UPDATE, INSERT. The transaction id is optional. 插入或更新行数据。操作针对数据的存在性包含三种检查类型:NO(不检查),UPDATE (更新,数据必须存在)和INSERT(插入,数据必须不存在)。事务ID是可选项。
@param builder The builder for putting a row. 插入或更新数据的Builder。 @return Void. 无返回值。
func (*TableStoreClient) SQLQuery ¶ added in v1.7.3
func (client *TableStoreClient) SQLQuery(req *SQLQueryRequest) (*SQLQueryResponse, error)
func (*TableStoreClient) Search ¶
func (tableStoreClient *TableStoreClient) Search(request *SearchRequest) (*SearchResponse, error)
func (*TableStoreClient) SetRetryNotify ¶ added in v1.7.11
func (tableStoreClient *TableStoreClient) SetRetryNotify(retryNotify RetryNotify)
func (*TableStoreClient) StartLocalTransaction ¶
func (client *TableStoreClient) StartLocalTransaction(request *StartLocalTransactionRequest) (*StartLocalTransactionResponse, error)
func (*TableStoreClient) UpdateRow ¶
func (tableStoreClient *TableStoreClient) UpdateRow(request *UpdateRowRequest) (*UpdateRowResponse, error)
Update row @param UpdateRowRequest
func (*TableStoreClient) UpdateSearchIndex ¶ added in v1.7.4
func (tableStoreClient *TableStoreClient) UpdateSearchIndex(request *UpdateSearchIndexRequest) (*UpdateSearchIndexResponse, error)
func (*TableStoreClient) UpdateTable ¶
func (tableStoreClient *TableStoreClient) UpdateTable(request *UpdateTableRequest) (*UpdateTableResponse, error)
Update the table info includes tableoptions and reservedthroughput @param UpdateTableRequest @param UpdateTableResponse
type TableStoreConfig ¶
type TableStoreConfig struct { RetryTimes uint MaxRetryTime time.Duration HTTPTimeout HTTPTimeout MaxIdleConnections int IdleConnTimeout time.Duration Transport http.RoundTripper DefaultRetryInterval time.Duration MaxRetryInterval time.Duration }
func NewDefaultTableStoreConfig ¶
func NewDefaultTableStoreConfig() *TableStoreConfig
type TableStoreHttpClient ¶
type TableStoreHttpClient struct {
// contains filtered or unexported fields
}
func (*TableStoreHttpClient) New ¶
func (httpClient *TableStoreHttpClient) New(client *http.Client)
type TablestoreSQLResultSet ¶ added in v1.7.3
type TablestoreSQLResultSet struct {
// contains filtered or unexported fields
}
func (*TablestoreSQLResultSet) Columns ¶ added in v1.7.3
func (rs *TablestoreSQLResultSet) Columns() []*SQLColumnInfo
func (*TablestoreSQLResultSet) HasNext ¶ added in v1.7.3
func (rs *TablestoreSQLResultSet) HasNext() bool
HasNext returns whether finished.
func (*TablestoreSQLResultSet) Next ¶ added in v1.7.3
func (rs *TablestoreSQLResultSet) Next() SQLRow
Next returns the next row of SQLResultSet.
func (*TablestoreSQLResultSet) Reset ¶ added in v1.7.3
func (rs *TablestoreSQLResultSet) Reset()
type TagMetaQueryCondition ¶ added in v1.7.0
type TagMetaQueryCondition struct { Operator MetaQuerySingleOperator TagName string Value string }
func NewTagMetaQueryCondition ¶ added in v1.7.0
func NewTagMetaQueryCondition(operator MetaQuerySingleOperator, tagName string, value string) *TagMetaQueryCondition
func (*TagMetaQueryCondition) GetType ¶ added in v1.7.0
func (TagMetaQueryCondition *TagMetaQueryCondition) GetType() MetaQueryConditionType
func (*TagMetaQueryCondition) Serialize ¶ added in v1.7.0
func (tagMetaQueryCondition *TagMetaQueryCondition) Serialize() []byte
type TaskSchema ¶ added in v1.6.0
type TaskSchema struct { ColumnName string OssColumnName string Type ParquetDataType Encode Encoding TypeExtend string }
type TaskSyncPhase ¶ added in v1.6.0
type TaskSyncPhase int32
const ( TaskInitStat TaskSyncPhase = iota TaskBaseStat TaskIncStat )
type TaskSyncStat ¶ added in v1.6.0
type TaskSyncStat struct { TaskSyncPhase TaskSyncPhase CurrentSyncTimestamp int64 ErrorCode ErrorType Detail string }
type TimeFormat ¶ added in v1.6.0
type TimeFormat int32
const ( EventColumnRFC822 TimeFormat = 1 EventColumnRFC850 TimeFormat = 2 EventColumnRFC1123 TimeFormat = 3 EventColumnRFC3339 TimeFormat = 4 EventColumnUnix TimeFormat = 5 )
type TimeseriesAnalyticalStore ¶ added in v1.7.8
type TimeseriesAnalyticalStore struct { StoreName string TimeToLive *int32 SyncOption *AnalyticalStoreSyncType }
func NewTimeseriesAnalyticalStore ¶ added in v1.7.8
func NewTimeseriesAnalyticalStore(analyticalStoreName string) *TimeseriesAnalyticalStore
func (*TimeseriesAnalyticalStore) SetSyncOption ¶ added in v1.7.8
func (analyticalStore *TimeseriesAnalyticalStore) SetSyncOption(syncOption AnalyticalStoreSyncType)
func (*TimeseriesAnalyticalStore) SetTimeToLive ¶ added in v1.7.8
func (analyticalStore *TimeseriesAnalyticalStore) SetTimeToLive(timeToLive int32)
type TimeseriesClient ¶ added in v1.7.0
type TimeseriesClient struct {
// contains filtered or unexported fields
}
func NewTimeseriesClient ¶ added in v1.7.0
func NewTimeseriesClient(endPoint, instanceName, accessKeyId, accessKeySecret string, options ...TimeseriesClientOption) *TimeseriesClient
func NewTimeseriesClientWithConfig ¶ added in v1.7.0
func NewTimeseriesClientWithConfig(endPoint, instanceName, accessKeyId, accessKeySecret string, securityToken string, config *TableStoreConfig, timeseriesConfiguration *TimeseriesConfiguration, options ...TimeseriesClientOption) *TimeseriesClient
func (*TimeseriesClient) CreateTimeseriesAnalyticalStore ¶ added in v1.7.8
func (timeseriesClient *TimeseriesClient) CreateTimeseriesAnalyticalStore(request *CreateTimeseriesAnalyticalStoreRequest) (*CreateTimeseriesAnalyticalStoreResponse, error)
func (*TimeseriesClient) CreateTimeseriesLastpointIndex ¶ added in v1.7.15
func (timeseriesClient *TimeseriesClient) CreateTimeseriesLastpointIndex( request *CreateTimeseriesLastpointIndexRequest) (*CreateTimeseriesLastpointIndexResponse, error)
func (*TimeseriesClient) CreateTimeseriesTable ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) CreateTimeseriesTable(request *CreateTimeseriesTableRequest) (*CreateTimeseriesTableResponse, error)
Create a timeseries table with CreateTimeseriesTableRequest. in which the timeseriesname and tableOptions are required. 根据CreateTimeseriesTableRequest创建一个时序表,其中表名和表选项是必选项
@param request of CreateTimeseriesTableRequest。 @return Void. 无返回值。
func (*TimeseriesClient) DeleteTimeseriesAnalyticalStore ¶ added in v1.7.8
func (timeseriesClient *TimeseriesClient) DeleteTimeseriesAnalyticalStore(request *DeleteTimeseriesAnalyticalStoreRequest) (*DeleteTimeseriesAnalyticalStoreResponse, error)
func (*TimeseriesClient) DeleteTimeseriesLastpointIndex ¶ added in v1.7.15
func (timeseriesClient *TimeseriesClient) DeleteTimeseriesLastpointIndex( request *DeleteTimeseriesLastpointIndexRequest) (*DeleteTimeseriesLastpointIndexResponse, error)
func (*TimeseriesClient) DeleteTimeseriesMeta ¶ added in v1.7.3
func (timeseriesClient *TimeseriesClient) DeleteTimeseriesMeta(request *DeleteTimeseriesMetaRequest) (*DeleteTimeseriesMetaResponse, error)
delete timeseries meta 删除时间线元数据
@param DeleteTimeseriesMetaRequest @return DeleteTimeseriesMetaResponse
func (*TimeseriesClient) DeleteTimeseriesTable ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) DeleteTimeseriesTable(request *DeleteTimeseriesTableRequest) (*DeleteTimeseriesTableResponse, error)
Delete a timeseries table 删除一个时序表
@param DeleteTimeseriesTableRequest return Void
func (*TimeseriesClient) DescribeTimeseriesAnalyticalStore ¶ added in v1.7.8
func (timeseriesClient *TimeseriesClient) DescribeTimeseriesAnalyticalStore(request *DescribeTimeseriesAnalyticalStoreRequest) (*DescribeTimeseriesAnalyticalStoreResponse, error)
func (*TimeseriesClient) DescribeTimeseriesTable ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) DescribeTimeseriesTable(request *DescribeTimeseriesTableRequest) (*DescribeTimeseriesTableResponse, error)
Get timeseries table meta infomation 获取指定时序表的元数据
@param request of DescribeTimeseriesTableRequest. @return TimeseriesTableMeta
func (*TimeseriesClient) GetTimeseriesData ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) GetTimeseriesData(request *GetTimeseriesDataRequest) (*GetTimeseriesDataResponse, error)
row API Get the timeseries data of a row or some columns. 获取某一时间线的一个或多个数据点
@param GetTimeseriesDataRequest @return GetTimeseriesDataResponse
func (*TimeseriesClient) GetTimeseriesMetaCache ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) GetTimeseriesMetaCache() *lruCache.Cache
func (*TimeseriesClient) ListTimeseriesTable ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) ListTimeseriesTable() (*ListTimeseriesTableResponse, error)
List all timeseries table name in this instance 列出该实例中的所有时序表的元数据信息
@param Void @return []*TimeseriesTableMeta
func (*TimeseriesClient) PutTimeseriesData ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) PutTimeseriesData(request *PutTimeseriesDataRequest) (*PutTimeseriesDataResponse, error)
Put a row in a timeseries table. The timeseriesTableName and TimeseriesRow are required. 插入新的时序数据,其中时序表名和时序数据行(可多行)作为参数
@param request of PutTimeseriesDataRequest。 @return FailedRowResult
func (*TimeseriesClient) QueryTimeseriesMeta ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) QueryTimeseriesMeta(request *QueryTimeseriesMetaRequest) (*QueryTimeseriesMetaResponse, error)
Query timeseries meta(measurement,tag,source) information in a timeseries table. 查询一个时序表中的时序元数据(measurement,tag,source)信息。
@param request of QueryTimeseriesMetaRequest @return meta information of one or more timeline: QueryTimeseriesMetaResponse
func (*TimeseriesClient) SetTimeseriesMetaCache ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) SetTimeseriesMetaCache(timeseriesMetaCache *lruCache.Cache)
func (*TimeseriesClient) UpdateTimeseriesAnalyticalStore ¶ added in v1.7.8
func (timeseriesClient *TimeseriesClient) UpdateTimeseriesAnalyticalStore(request *UpdateTimeseriesAnalyticalStoreRequest) (*UpdateTimeseriesAnalyticalStoreResponse, error)
func (*TimeseriesClient) UpdateTimeseriesMeta ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) UpdateTimeseriesMeta(request *UpdateTimeseriesMetaRequest) (*UpdateTimeseriesMetaResponse, error)
update timeseries attributes for time line. 更新时间线的属性信息
@param UpdateTimeseriesMetaRequest @return UpdateTimeseriesMetaResponse
func (*TimeseriesClient) UpdateTimeseriesTable ¶ added in v1.7.0
func (timeseriesClient *TimeseriesClient) UpdateTimeseriesTable(request *UpdateTimeseriesTableRequest) (*UpdateTimeseriesTableResponse, error)
update timeInus parameter for a timeseries table. 更新一个时序表的TTL参数
@param UpdateTimeseriesTableRequest @return Void
type TimeseriesClientOption ¶ added in v1.7.0
type TimeseriesClientOption func(client *TimeseriesClient)
type TimeseriesConfiguration ¶ added in v1.7.0
type TimeseriesConfiguration struct {
// contains filtered or unexported fields
}
func NewTimeseriesConfiguration ¶ added in v1.7.0
func NewTimeseriesConfiguration() *TimeseriesConfiguration
func (*TimeseriesConfiguration) GetMetaCacheMaxDataSize ¶ added in v1.7.0
func (this *TimeseriesConfiguration) GetMetaCacheMaxDataSize() int
func (*TimeseriesConfiguration) SetMetaCacheMaxDataSize ¶ added in v1.7.0
func (this *TimeseriesConfiguration) SetMetaCacheMaxDataSize(metaCacheMaxDataSize int)
type TimeseriesKey ¶ added in v1.7.0
type TimeseriesKey struct {
// contains filtered or unexported fields
}
func NewTimeseriesKey ¶ added in v1.7.0
func NewTimeseriesKey() *TimeseriesKey
func (*TimeseriesKey) AddTag ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) AddTag(tagName string, tagValue string)
func (*TimeseriesKey) AddTags ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) AddTags(tagsMap map[string]string)
func (*TimeseriesKey) GetDataSource ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) GetDataSource() string
func (*TimeseriesKey) GetMeasurementName ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) GetMeasurementName() string
func (*TimeseriesKey) GetTags ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) GetTags() map[string]string
func (*TimeseriesKey) SetDataSource ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) SetDataSource(source string)
func (*TimeseriesKey) SetMeasurementName ¶ added in v1.7.0
func (timeseriesKey *TimeseriesKey) SetMeasurementName(measurementName string)
type TimeseriesMeta ¶ added in v1.7.0
type TimeseriesMeta struct {
// contains filtered or unexported fields
}
func NewTimeseriesMeta ¶ added in v1.7.0
func NewTimeseriesMeta(timeseriesKey *TimeseriesKey) *TimeseriesMeta
func (*TimeseriesMeta) AddAttribute ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) AddAttribute(attr_key string, attr_value string)
func (*TimeseriesMeta) AddAttributes ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) AddAttributes(attributes map[string]string)
func (*TimeseriesMeta) GetAttributeSlice ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) GetAttributeSlice() string
func (*TimeseriesMeta) GetAttributes ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) GetAttributes() map[string]string
func (*TimeseriesMeta) GetTimeseriesKey ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) GetTimeseriesKey() *TimeseriesKey
func (*TimeseriesMeta) GetUpdateTimeInUs ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) GetUpdateTimeInUs() int64
func (*TimeseriesMeta) SetTimeseriesKey ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
func (*TimeseriesMeta) SetUpdateTimeInUs ¶ added in v1.7.0
func (timeseriesMeta *TimeseriesMeta) SetUpdateTimeInUs(updateTimeInUs int64)
type TimeseriesRow ¶ added in v1.7.0
type TimeseriesRow struct {
// contains filtered or unexported fields
}
func NewTimeseriesRow ¶ added in v1.7.0
func NewTimeseriesRow(timeseriesKey *TimeseriesKey) *TimeseriesRow
func (*TimeseriesRow) AddField ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) AddField(fieldName string, fieldValue *ColumnValue)
func (*TimeseriesRow) AddFields ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) AddFields(fieldsMap map[string]*ColumnValue)
func (*TimeseriesRow) GetFieldsMap ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) GetFieldsMap() map[string]*ColumnValue
func (*TimeseriesRow) GetTimeInus ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) GetTimeInus() int64
func (*TimeseriesRow) GetTimeseriesKey ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) GetTimeseriesKey() *TimeseriesKey
func (*TimeseriesRow) SetTimeInus ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) SetTimeInus(timestamp int64)
func (*TimeseriesRow) SetTimeseriesKey ¶ added in v1.7.0
func (timeseriesRow *TimeseriesRow) SetTimeseriesKey(timeseriesKey *TimeseriesKey)
type TimeseriesTableMeta ¶ added in v1.7.0
type TimeseriesTableMeta struct {
// contains filtered or unexported fields
}
func NewTimeseriesTableMeta ¶ added in v1.7.0
func NewTimeseriesTableMeta(timeseriesTableName string) *TimeseriesTableMeta
func ParseTimeseriesTableMeta ¶ added in v1.7.0
func ParseTimeseriesTableMeta(pbResponseTableMeta *otsprotocol.TimeseriesTableMeta) *TimeseriesTableMeta
func (*TimeseriesTableMeta) AddFieldPrimaryKey ¶ added in v1.7.15
func (timeseriesTableMeta *TimeseriesTableMeta) AddFieldPrimaryKey(name string, primaryKeyType PrimaryKeyType)
func (*TimeseriesTableMeta) AddTimeseriesKey ¶ added in v1.7.15
func (timeseriesTableMeta *TimeseriesTableMeta) AddTimeseriesKey(name string)
func (*TimeseriesTableMeta) GetFieldPrimaryKeys ¶ added in v1.7.15
func (timeseriesTableMeta *TimeseriesTableMeta) GetFieldPrimaryKeys() []*PrimaryKeySchema
func (*TimeseriesTableMeta) GetTimeseriesKeys ¶ added in v1.7.15
func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesKeys() []string
func (*TimeseriesTableMeta) GetTimeseriesTableName ¶ added in v1.7.0
func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesTableName() string
func (*TimeseriesTableMeta) GetTimeseriesTableOPtions ¶ added in v1.7.0
func (timeseriesTableMeta *TimeseriesTableMeta) GetTimeseriesTableOPtions() *TimeseriesTableOptions
func (*TimeseriesTableMeta) SetTimeseriesTableName ¶ added in v1.7.0
func (timeseriesTableMeta *TimeseriesTableMeta) SetTimeseriesTableName(timeseriesTableName string)
func (*TimeseriesTableMeta) SetTimeseriesTableOptions ¶ added in v1.7.0
func (timeseriesTableMeta *TimeseriesTableMeta) SetTimeseriesTableOptions(timeseriesTableOptions *TimeseriesTableOptions)
type TimeseriesTableOptions ¶ added in v1.7.0
type TimeseriesTableOptions struct {
// contains filtered or unexported fields
}
func NewTimeseriesTableOptions ¶ added in v1.7.0
func NewTimeseriesTableOptions(timeToLive int64) *TimeseriesTableOptions
func (*TimeseriesTableOptions) GetTimeToLive ¶ added in v1.7.0
func (timeseriesTableOptions *TimeseriesTableOptions) GetTimeToLive() int64
func (*TimeseriesTableOptions) SetTimetoLive ¶ added in v1.7.0
func (timeseriesTableOptions *TimeseriesTableOptions) SetTimetoLive(timetoLive int64)
type UpdateRowChange ¶
type UpdateRowChange struct { TableName string PrimaryKey *PrimaryKey Columns []ColumnToUpdate Condition *RowCondition TransactionId *string ReturnType ReturnType ColumnNamesToReturn []string }
func (*UpdateRowChange) AppendIncrementColumnToReturn ¶
func (rowchange *UpdateRowChange) AppendIncrementColumnToReturn(name string)
func (*UpdateRowChange) DeleteColumn ¶
func (rowchange *UpdateRowChange) DeleteColumn(columnName string)
func (*UpdateRowChange) DeleteColumnWithTimestamp ¶
func (rowchange *UpdateRowChange) DeleteColumnWithTimestamp(columnName string, timestamp int64)
func (*UpdateRowChange) GetTableName ¶
func (rowchange *UpdateRowChange) GetTableName() string
func (*UpdateRowChange) IncrementColumn ¶
func (rowchange *UpdateRowChange) IncrementColumn(columnName string, value int64)
func (*UpdateRowChange) PutColumn ¶
func (rowchange *UpdateRowChange) PutColumn(columnName string, value interface{})
value only support int64,string,bool,float64,[]byte. other type will get panic
func (*UpdateRowChange) PutColumnWithTimestamp ¶
func (rowchange *UpdateRowChange) PutColumnWithTimestamp(columnName string, value interface{}, timestamp int64)
value only support int64,string,bool,float64,[]byte. other type will get panic
func (*UpdateRowChange) Serialize ¶
func (rowchange *UpdateRowChange) Serialize() []byte
func (*UpdateRowChange) SetColumnCondition ¶
func (rowchange *UpdateRowChange) SetColumnCondition(condition ColumnFilter)
func (*UpdateRowChange) SetCondition ¶
func (rowchange *UpdateRowChange) SetCondition(rowExistenceExpectation RowExistenceExpectation)
func (*UpdateRowChange) SetReturnIncrementValue ¶
func (rowchange *UpdateRowChange) SetReturnIncrementValue()
type UpdateRowRequest ¶
type UpdateRowRequest struct { UpdateRowChange *UpdateRowChange ExtraRequestInfo }
type UpdateRowResponse ¶
type UpdateRowResponse struct { Columns []*AttributeColumn ConsumedCapacityUnit *ConsumedCapacityUnit ResponseInfo }
type UpdateSearchIndexRequest ¶ added in v1.7.4
type UpdateSearchIndexRequest struct { TableName string IndexName string SwitchIndexName *string QueryFlowWeights []*QueryFlowWeight TimeToLive *int32 ExtraRequestInfo }
type UpdateSearchIndexResponse ¶ added in v1.7.4
type UpdateSearchIndexResponse struct {
ResponseInfo ResponseInfo
}
type UpdateTableRequest ¶
type UpdateTableRequest struct { TableName string TableOption *TableOption ReservedThroughput *ReservedThroughput StreamSpec *StreamSpecification ExtraRequestInfo }
type UpdateTableResponse ¶
type UpdateTableResponse struct { TableOption *TableOption ReservedThroughput *ReservedThroughput StreamDetails *StreamDetails ResponseInfo }
type UpdateTimeMetaQueryCondition ¶ added in v1.7.0
type UpdateTimeMetaQueryCondition struct { Operator MetaQuerySingleOperator TimeInUs int64 }
func NewUpdateTimeMetaQueryCondition ¶ added in v1.7.0
func NewUpdateTimeMetaQueryCondition(operator MetaQuerySingleOperator, timeInUs int64) *UpdateTimeMetaQueryCondition
func (*UpdateTimeMetaQueryCondition) GetType ¶ added in v1.7.0
func (updateTimeMetaQueryCondition *UpdateTimeMetaQueryCondition) GetType() MetaQueryConditionType
func (*UpdateTimeMetaQueryCondition) Serialize ¶ added in v1.7.0
func (updateTimeMetaQueryCondition *UpdateTimeMetaQueryCondition) Serialize() []byte
type UpdateTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
type UpdateTimeseriesAnalyticalStoreRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewUpdateTimeseriesAnalyticalStoreRequest ¶ added in v1.7.8
func NewUpdateTimeseriesAnalyticalStoreRequest(timeseriesTableName string, analyticalStore *TimeseriesAnalyticalStore) *UpdateTimeseriesAnalyticalStoreRequest
type UpdateTimeseriesAnalyticalStoreResponse ¶ added in v1.7.8
type UpdateTimeseriesAnalyticalStoreResponse struct {
ResponseInfo
}
type UpdateTimeseriesMetaRequest ¶ added in v1.7.0
type UpdateTimeseriesMetaRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
func NewUpdateTimeseriesMetaRequest ¶ added in v1.7.0
func NewUpdateTimeseriesMetaRequest(timeseriesTableName string) *UpdateTimeseriesMetaRequest
func (*UpdateTimeseriesMetaRequest) AddTimeseriesMetas ¶ added in v1.7.0
func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) AddTimeseriesMetas(metas ...*TimeseriesMeta)
func (*UpdateTimeseriesMetaRequest) GetTimeseriesMetas ¶ added in v1.7.0
func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) GetTimeseriesMetas() []*TimeseriesMeta
func (*UpdateTimeseriesMetaRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) GetTimeseriesTableName() string
func (*UpdateTimeseriesMetaRequest) SetTimeseriesTableName ¶ added in v1.7.0
func (updateTimeseriesMetaRequest *UpdateTimeseriesMetaRequest) SetTimeseriesTableName(timeseriesTableName string)
type UpdateTimeseriesMetaResponse ¶ added in v1.7.0
type UpdateTimeseriesMetaResponse struct { ResponseInfo // contains filtered or unexported fields }
func (*UpdateTimeseriesMetaResponse) GetFailedRowResults ¶ added in v1.7.0
func (updateTimeseriesMetaResponse *UpdateTimeseriesMetaResponse) GetFailedRowResults() []*FailedRowResult
type UpdateTimeseriesTableRequest ¶ added in v1.7.0
type UpdateTimeseriesTableRequest struct { ExtraRequestInfo // contains filtered or unexported fields }
UpdateTimeseriesTableRequest
func NewUpdateTimeseriesTableRequest ¶ added in v1.7.0
func NewUpdateTimeseriesTableRequest(timeseriesTableName string) *UpdateTimeseriesTableRequest
func (*UpdateTimeseriesTableRequest) GetTimeseriesTableName ¶ added in v1.7.0
func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) GetTimeseriesTableName() string
func (*UpdateTimeseriesTableRequest) GetTimeseriesTableOptions ¶ added in v1.7.0
func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) GetTimeseriesTableOptions() *TimeseriesTableOptions
func (*UpdateTimeseriesTableRequest) SetTimeseriesTableOptions ¶ added in v1.7.0
func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) SetTimeseriesTableOptions(timeseriesTableOptions *TimeseriesTableOptions)
func (*UpdateTimeseriesTableRequest) SetTimeseriesTalbeName ¶ added in v1.7.0
func (updateTimeseriesTableReq *UpdateTimeseriesTableRequest) SetTimeseriesTalbeName(timeseriesTableName string)
type UpdateTimeseriesTableResponse ¶ added in v1.7.0
type UpdateTimeseriesTableResponse struct {
ResponseInfo
}
type ValueTransferRule ¶
type ValueTransferRule struct { Regex string Cast_type VariantType }
func NewValueTransferRule ¶
func NewValueTransferRule(regex string, vt VariantType) *ValueTransferRule
type VariantType ¶
type VariantType int32
const ( Variant_INTEGER VariantType = 0 Variant_DOUBLE VariantType = 1 //VT_BOOLEAN = 2; Variant_STRING VariantType = 3 )
type VectorDataType ¶ added in v1.7.13
type VectorDataType string
const (
VectorDataType_FLOAT_32 VectorDataType = "float_32"
)
func (VectorDataType) Enum ¶ added in v1.7.13
func (dataType VectorDataType) Enum() *VectorDataType
type VectorMetricType ¶ added in v1.7.13
type VectorMetricType string
const ( VectorMetricType_EUCLIDEAN VectorMetricType = "euclidean" VectorMetricType_COSINE VectorMetricType = "cosine" VectorMetricType_DOT_PRODUCT VectorMetricType = "dot_product" )
func (VectorMetricType) Enum ¶ added in v1.7.13
func (metricType VectorMetricType) Enum() *VectorMetricType
type VectorOptions ¶ added in v1.7.13
type VectorOptions struct { VectorDataType *VectorDataType VectorMetricType *VectorMetricType Dimension *int32 }