topicoptions

package
v3.115.7 Latest Latest
Warning

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

Go to latest
Published: Sep 10, 2025 License: Apache-2.0 Imports: 13 Imported by: 10

Documentation

Index

Examples

Constants

View Source
const (
	// CommitModeAsync - commit return true if commit success add to internal send buffer (but not sent to server)
	// now it is grpc buffer, in feature it may be internal sdk buffer
	CommitModeAsync = topicreadercommon.CommitModeAsync // default

	// CommitModeNone - reader will not be commit operation
	CommitModeNone = topicreadercommon.CommitModeNone

	// CommitModeSync - commit return true when sdk receive ack of commit from server
	// The mode needs strong ordering client code for prevent deadlock.
	// Example:
	// Good:
	// CommitOffset(1)
	// CommitOffset(2)
	//
	// Error:
	// CommitOffset(2) - server will wait commit offset 1 before send ack about offset 1 and 2 committed.
	// CommitOffset(1)
	// SDK will detect the problem and return error instead of deadlock.
	CommitModeSync = topicreadercommon.CommitModeSync
)

Variables

View Source
var (
	CheckErrorRetryDecisionDefault = topic.PublicRetryDecisionDefault // Apply default behavior for the error
	CheckErrorRetryDecisionRetry   = topic.PublicRetryDecisionRetry   // Do once more retry
	CheckErrorRetryDecisionStop    = topic.PublicRetryDecisionStop    // Do not retry
)

Functions

This section is empty.

Types

type AlterOption

type AlterOption interface {
	ApplyAlterOption(req *rawtopic.AlterTopicRequest)
}

AlterOption type of options for change topic settings

func AlterConsumerWithAttributes

func AlterConsumerWithAttributes(name string, attributes map[string]string) AlterOption

AlterConsumerWithAttributes change attributes of the consumer

func AlterConsumerWithImportant

func AlterConsumerWithImportant(name string, important bool) AlterOption

AlterConsumerWithImportant set/remove important flag for the consumer of topic

func AlterConsumerWithReadFrom

func AlterConsumerWithReadFrom(name string, readFrom time.Time) AlterOption

AlterConsumerWithReadFrom change min time of messages, received for the topic

func AlterConsumerWithSupportedCodecs

func AlterConsumerWithSupportedCodecs(name string, codecs []topictypes.Codec) AlterOption

AlterConsumerWithSupportedCodecs change codecs, supported by the consumer

func AlterWithAddConsumers

func AlterWithAddConsumers(consumers ...topictypes.Consumer) AlterOption

AlterWithAddConsumers add consumer to the topic

func AlterWithAttributes

func AlterWithAttributes(attributes map[string]string) AlterOption

AlterWithAttributes change attributes map of topic

func AlterWithAutoPartitioningStrategy added in v3.109.0

func AlterWithAutoPartitioningStrategy(strategy topictypes.AutoPartitioningStrategy) AlterOption

AlterWithAutoPartitioningStrategy change auto partitioning strategy for the topic

func AlterWithAutoPartitioningWriteSpeedDownUtilizationPercent added in v3.109.0

func AlterWithAutoPartitioningWriteSpeedDownUtilizationPercent(percent int32) AlterOption

AlterWithAutoPartitioningWriteSpeedDownUtilizationPercent change down utilization percent for auto partitioning write speed

func AlterWithAutoPartitioningWriteSpeedStabilizationWindow added in v3.109.0

func AlterWithAutoPartitioningWriteSpeedStabilizationWindow(window time.Duration) AlterOption

AlterWithAutoPartitioningWriteSpeedStabilizationWindow change stabilization window for auto partitioning write speed

func AlterWithAutoPartitioningWriteSpeedUpUtilizationPercent added in v3.109.0

func AlterWithAutoPartitioningWriteSpeedUpUtilizationPercent(percent int32) AlterOption

AlterWithAutoPartitioningWriteSpeedUpUtilizationPercent change up utilization percent for auto partitioning write speed

func AlterWithDropConsumers

func AlterWithDropConsumers(consumersName ...string) AlterOption

AlterWithDropConsumers drop consumer from the topic

func AlterWithMaxActivePartitions added in v3.109.0

func AlterWithMaxActivePartitions(maxActivePartitions int64) AlterOption

AlterWithMaxActivePartitions change max active partitions of the topic

func AlterWithMeteringMode added in v3.38.2

func AlterWithMeteringMode(m topictypes.MeteringMode) AlterOption

AlterWithMeteringMode change metering mode for topic (need for serverless installations)

func AlterWithMinActivePartitions

func AlterWithMinActivePartitions(minActivePartitions int64) AlterOption

AlterWithMinActivePartitions change min active partitions of the topic

func AlterWithPartitionCountLimit

func AlterWithPartitionCountLimit(partitionCountLimit int64) AlterOption

AlterWithPartitionCountLimit change partition count limit of the topic

func AlterWithPartitionWriteBurstBytes

func AlterWithPartitionWriteBurstBytes(burstBytes int64) AlterOption

AlterWithPartitionWriteBurstBytes change burst size for write to partition of topic

func AlterWithPartitionWriteSpeedBytesPerSecond

func AlterWithPartitionWriteSpeedBytesPerSecond(bytesPerSecond int64) AlterOption

AlterWithPartitionWriteSpeedBytesPerSecond change limit of write speed for partitions of the topic

func AlterWithRetentionPeriod

func AlterWithRetentionPeriod(retentionPeriod time.Duration) AlterOption

AlterWithRetentionPeriod change retention period of topic

func AlterWithRetentionStorageMB

func AlterWithRetentionStorageMB(retentionStorageMB int64) AlterOption

AlterWithRetentionStorageMB change retention storage size in MB.

func AlterWithSupportedCodecs

func AlterWithSupportedCodecs(codecs ...topictypes.Codec) AlterOption

AlterWithSupportedCodecs change set of codec, allowed for the topic

type CheckErrorRetryArgs added in v3.42.0

type CheckErrorRetryArgs = topic.PublicCheckErrorRetryArgs

type CheckErrorRetryFunction added in v3.42.0

type CheckErrorRetryFunction = topic.PublicCheckErrorRetryFunction

type CheckErrorRetryResult added in v3.42.0

type CheckErrorRetryResult = topic.PublicCheckRetryResult

type CommitMode

CommitMode variants of commit mode of the reader

type CreateDecoderFunc

type CreateDecoderFunc = topicreadercommon.PublicCreateDecoderFunc

CreateDecoderFunc interface for fabric of message decoders

type CreateEncoderFunc added in v3.38.0

type CreateEncoderFunc = topicwriterinternal.PublicCreateEncoderFunc

CreateEncoderFunc for create message decoders

type CreateOption

type CreateOption interface {
	ApplyCreateOption(request *rawtopic.CreateTopicRequest)
}

CreateOption type for options of topic create

func CreateWithAttributes

func CreateWithAttributes(attributes map[string]string) CreateOption

CreateWithAttributes set attributes for the topic.

func CreateWithAutoPartitioningSettings added in v3.109.0

func CreateWithAutoPartitioningSettings(settings topictypes.AutoPartitioningSettings) CreateOption

CreateWithAutoPartitioningSettings set auto partitioning settings for the topic

func CreateWithConsumer

func CreateWithConsumer(consumers ...topictypes.Consumer) CreateOption

CreateWithConsumer create new consumers with the topic

func CreateWithMaxActivePartitions added in v3.109.0

func CreateWithMaxActivePartitions(count int64) CreateOption

CreateWithMaxActivePartitions set max active partitions for the topic

func CreateWithMeteringMode added in v3.38.2

func CreateWithMeteringMode(mode topictypes.MeteringMode) CreateOption

CreateWithMeteringMode set metering mode for the topic

func CreateWithMinActivePartitions

func CreateWithMinActivePartitions(count int64) CreateOption

CreateWithMinActivePartitions set min active partitions for the topic

func CreateWithPartitionCountLimit

func CreateWithPartitionCountLimit(count int64) CreateOption

CreateWithPartitionCountLimit set partition count limit for the topic Deprecated: Use CreateWithMaxActivePartitions instead. Will be removed after Nov 2025. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func CreateWithPartitionWriteBurstBytes

func CreateWithPartitionWriteBurstBytes(partitionWriteBurstBytes int64) CreateOption

CreateWithPartitionWriteBurstBytes set burst limit for partitions of the topic

func CreateWithPartitionWriteSpeedBytesPerSecond

func CreateWithPartitionWriteSpeedBytesPerSecond(partitionWriteSpeedBytesPerSecond int64) CreateOption

CreateWithPartitionWriteSpeedBytesPerSecond set write size limit for partitions of the topic

func CreateWithRetentionPeriod

func CreateWithRetentionPeriod(retentionPeriod time.Duration) CreateOption

CreateWithRetentionPeriod set retention time interval for the topic.

func CreateWithRetentionStorageMB

func CreateWithRetentionStorageMB(retentionStorageMB int64) CreateOption

CreateWithRetentionStorageMB set retention size for the topic.

func CreateWithSupportedCodecs added in v3.38.2

func CreateWithSupportedCodecs(codecs ...topictypes.Codec) CreateOption

CreateWithSupportedCodecs set supported codecs for the topic

type DescribeConsumerOption added in v3.85.0

type DescribeConsumerOption func(req *rawtopic.DescribeConsumerRequest)

DescribeConsumerOption type for options of describe consumer method.

func IncludeConsumerStats added in v3.85.0

func IncludeConsumerStats() DescribeConsumerOption

IncludeConsumerStats additionally fetches DescribeConsumerResult.DescribeConsumerResultPartitionInfo.PartitionConsumerStats from server

type DescribeOption

type DescribeOption func(req *rawtopic.DescribeTopicRequest)

DescribeOption type for options of describe method.

func IncludePartitionStats added in v3.107.0

func IncludePartitionStats() DescribeOption

IncludePartitionStats additionally fetches DescribeTopicResult.PartitionInfo.PartitioningSettings from server

type DropOption

type DropOption interface {
	ApplyDropOption(request *rawtopic.DropTopicRequest)
}

DropOption type for drop options. Not used now.

type GetPartitionStartOffsetFunc

type GetPartitionStartOffsetFunc = topicreaderinternal.PublicGetPartitionStartOffsetFunc

GetPartitionStartOffsetFunc callback function for optional handle start partition event and manage read progress at own side. It can call multiply times in parallel.

type GetPartitionStartOffsetRequest

type GetPartitionStartOffsetRequest = topicreaderinternal.PublicGetPartitionStartOffsetRequest

GetPartitionStartOffsetRequest info about the partition

type GetPartitionStartOffsetResponse

type GetPartitionStartOffsetResponse = topicreaderinternal.PublicGetPartitionStartOffsetResponse

GetPartitionStartOffsetResponse optional set offset for start reade messages for the partition

type ListenerOption added in v3.76.0

type ListenerOption func(cfg *topiclistenerinternal.StreamListenerConfig)

ListenerOption set settings for topic listener struct

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithListenerAddDecoder added in v3.76.0

func WithListenerAddDecoder(codec topictypes.Codec, decoderCreate CreateDecoderFunc) ListenerOption

WithListenerAddDecoder add decoder for a codec. It allows to set decoders fabric for custom codec and replace internal decoders.

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

type OnWriterInitResponseCallback deprecated added in v3.38.0

type OnWriterInitResponseCallback = topicwriterinternal.PublicOnWriterInitResponseCallback

OnWriterInitResponseCallback

Deprecated: was experimental and not actual now. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

type ReadSelector

ReadSelector set rules for reader: set of topic, partitions, start time filted, etc.

type ReadSelectors

type ReadSelectors []ReadSelector

ReadSelectors slice of rules for topic reader

func ReadTopic

func ReadTopic(path string) ReadSelectors

ReadTopic create simple selector for read topics, if no need special settings.

type ReaderOption

ReaderOption options for topic reader

func WithAddDecoder

func WithAddDecoder(codec topictypes.Codec, decoderCreate CreateDecoderFunc) ReaderOption

WithAddDecoder add decoder for a codec. It allows to set decoders fabric for custom codec and replace internal decoders.

func WithBatchReadMaxCount deprecated

func WithBatchReadMaxCount(count int) ReaderOption

WithBatchReadMaxCount

Deprecated: was experimental and not actual now. Use WithReaderBatchMaxCount instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithBatchReadMinCount deprecated

func WithBatchReadMinCount(count int) ReaderOption

WithBatchReadMinCount prefer min count messages in batch sometimes batch can contain fewer messages, for example if local buffer is full and SDK can't receive more messages

Deprecated: was experimental and not actual now. The option will be removed for simplify code internals. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithCommitCountTrigger deprecated

func WithCommitCountTrigger(count int) ReaderOption

WithCommitCountTrigger

Deprecated: was experimental and not actual now. Use WithReaderCommitCountTrigger instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithCommitMode deprecated

func WithCommitMode(mode CommitMode) ReaderOption

WithCommitMode

Deprecated: was experimental and not actual now. Use WithReaderCommitMode instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithCommitTimeLagTrigger deprecated

func WithCommitTimeLagTrigger(lag time.Duration) ReaderOption

WithCommitTimeLagTrigger

Deprecated: was experimental and not actual now. Use WithReaderCommitTimeLagTrigger instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithGetPartitionStartOffset deprecated

func WithGetPartitionStartOffset(f GetPartitionStartOffsetFunc) ReaderOption

WithGetPartitionStartOffset

Deprecated: was experimental and not actual now. Use WithReaderGetPartitionStartOffset instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithMessagesBufferSize deprecated

func WithMessagesBufferSize(size int) ReaderOption

WithMessagesBufferSize

Deprecated: was experimental and not actual now. Use WithReaderBufferSizeBytes instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithReaderBatchMaxCount added in v3.52.3

func WithReaderBatchMaxCount(count int) ReaderOption

WithReaderBatchMaxCount set max messages count, returned by topic.TopicReader.ReadBatch method

func WithReaderBufferSizeBytes added in v3.52.3

func WithReaderBufferSizeBytes(size int) ReaderOption

WithReaderBufferSizeBytes set size of internal buffer for read ahead messages.

func WithReaderCheckRetryErrorFunction added in v3.42.0

func WithReaderCheckRetryErrorFunction(callback CheckErrorRetryFunction) ReaderOption

WithReaderCheckRetryErrorFunction can override default error retry policy use CheckErrorRetryDecisionDefault for use default behavior for the error callback func must be fast and deterministic: always result same result for same error - it can be called few times for every error

Example
var db *ydb.Driver

reader, err := db.Topic().StartReader(
	"consumer",
	topicoptions.ReadTopic("topic"),
	topicoptions.WithReaderCheckRetryErrorFunction(
		func(errInfo topicoptions.CheckErrorRetryArgs) topicoptions.CheckErrorRetryResult {
			// Retry not found operations
			if ydb.IsOperationErrorNotFoundError(errInfo.Error) {
				return topicoptions.CheckErrorRetryDecisionRetry
			}

			// and use default behavior for all other errors
			return topicoptions.CheckErrorRetryDecisionDefault
		}),
)
_, _ = reader, err

func WithReaderCommitCountTrigger added in v3.52.3

func WithReaderCommitCountTrigger(count int) ReaderOption

WithReaderCommitCountTrigger set count trigger for send batch to server if count > 0 and sdk count of buffered commits >= count - send commit request to server 0 mean no count limit and use timer lag trigger only

func WithReaderCommitMode added in v3.52.3

func WithReaderCommitMode(mode CommitMode) ReaderOption

WithReaderCommitMode set commit mode to the reader

func WithReaderCommitTimeLagTrigger added in v3.52.3

func WithReaderCommitTimeLagTrigger(lag time.Duration) ReaderOption

WithReaderCommitTimeLagTrigger set time lag from first commit message before send commit to server for accumulate many similar-time commits to one server request 0 mean no additional lag and send commit soon as possible Default value: 1 second

func WithReaderGetPartitionStartOffset added in v3.52.3

func WithReaderGetPartitionStartOffset(f GetPartitionStartOffsetFunc) ReaderOption

WithReaderGetPartitionStartOffset set optional handler for own manage progress of read partitions instead of/additional to commit messages

func WithReaderLogContext added in v3.108.4

func WithReaderLogContext(ctx context.Context) ReaderOption

WithReaderLogContext allows providing a context.Context instance which will be used in log/topic events.

func WithReaderOperationCancelAfter

func WithReaderOperationCancelAfter(cancelAfter time.Duration) ReaderOption

WithReaderOperationCancelAfter

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithReaderOperationTimeout

func WithReaderOperationTimeout(timeout time.Duration) ReaderOption

WithReaderOperationTimeout

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithReaderStartTimeout added in v3.42.0

func WithReaderStartTimeout(timeout time.Duration) ReaderOption

WithReaderStartTimeout mean timeout for connect to reader stream and work some time without errors

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithReaderSupportSplitMergePartitions added in v3.106.0

func WithReaderSupportSplitMergePartitions(enableSupport bool) ReaderOption

WithReaderSupportSplitMergePartitions set support of split and merge partitions on client side. Default is true, set false for disable the support.

func WithReaderTrace added in v3.32.0

func WithReaderTrace(t trace.Topic) ReaderOption

WithReaderTrace set tracer for the topic reader

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithReaderUpdateTokenInterval added in v3.41.0

func WithReaderUpdateTokenInterval(interval time.Duration) ReaderOption

WithReaderUpdateTokenInterval set custom interval for send update token message to the server

func WithReaderWithoutConsumer added in v3.68.0

func WithReaderWithoutConsumer(saveStateOnReconnection bool) ReaderOption

WithReaderWithoutConsumer allow read topic without consumer. Read without consumer is special read mode on a server. In the mode every reader without consumer receive all messages from a topic and can't commit them. The mode work good if every reader process need all messages (for example for cache invalidation) and no need scale process messages by readers count.

saveStateOnReconnection - if true: simulate one unbroken stream without duplicate messages (unimplemented) - if false: need store progress on client side for prevent re-read messages on internal reconnections to the server.

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental https://github.com/ydb-platform/ydb-go-sdk/issues/905

type ResetableWriter added in v3.98.0

ResettableWriter is able to reset a nested writer between uses.

type TopicOption

type TopicOption = topic.Option // func(c *topic.Config)

TopicOption

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithOperationCancelAfter

func WithOperationCancelAfter(operationCancelAfter time.Duration) TopicOption

WithOperationCancelAfter set the maximum amount of time a YDB server will process an operation. After timeout exceeds YDB will try to cancel operation and if it succeeds appropriate error will be returned to the client; otherwise processing will be continued. If OperationCancelAfter is zero then no timeout is used.

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithOperationTimeout

func WithOperationTimeout(operationTimeout time.Duration) TopicOption

WithOperationTimeout set the maximum amount of time a YDB server will process an operation. After timeout exceeds YDB will try to cancel operation and regardless of the cancellation appropriate error will be returned to the client. If OperationTimeout is zero then no timeout is used.

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithTrace

func WithTrace(trace trace.Topic, opts ...trace.TopicComposeOption) TopicOption

WithTrace defines trace over persqueue client calls

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

type WithOnWriterConnectedInfo deprecated added in v3.38.0

type WithOnWriterConnectedInfo = topicwriterinternal.PublicWithOnWriterConnectedInfo

WithOnWriterConnectedInfo present information, received from server

Deprecated: was experimental and not actual now. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

type WriteSessionMetadata added in v3.38.0

type WriteSessionMetadata map[string]string

WriteSessionMetadata set key-value metadata for write session. The metadata will allow for messages of the session in topic reader.

type WriterOption added in v3.38.0

WriterOption options for a topic writer

func WithCodec deprecated added in v3.38.0

func WithCodec(codec topictypes.Codec) WriterOption

WithCodec

Deprecated: was experimental and not actual now. Use WithWriterCodec instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithCodecAutoSelect deprecated added in v3.38.0

func WithCodecAutoSelect() WriterOption

WithCodecAutoSelect

Deprecated: was experimental and not actual now. Use WithWriterCodecAutoSelect instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithOnWriterFirstConnected deprecated added in v3.38.0

func WithOnWriterFirstConnected(f OnWriterInitResponseCallback) WriterOption

WithOnWriterFirstConnected set callback f, which will called once - after first successfully init topic writer stream

Deprecated: was experimental and not actual now. Use Writer.WaitInit function instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithPartitionID deprecated added in v3.38.0

func WithPartitionID(partitionID int64) WriterOption

WithPartitionID

Deprecated: was experimental and not actual now. Use WithWriterPartitionID instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithProducerID deprecated added in v3.43.0

func WithProducerID(producerID string) WriterOption

WithProducerID

Deprecated: was experimental and not actual now. Use WithWriterProducerID instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithSyncWrite deprecated added in v3.38.0

func WithSyncWrite(sync bool) WriterOption

WithSyncWrite

Deprecated: was experimental and not actual now. Use WithWriterWaitServerAck instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithWriteSessionMeta deprecated added in v3.38.0

func WithWriteSessionMeta(meta map[string]string) WriterOption

WithWriteSessionMeta

Deprecated: was experimental and not actual now. Use WithWriterSessionMeta instead. Will be removed after Oct 2024. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated

func WithWriterAddEncoder added in v3.38.0

func WithWriterAddEncoder(codec topictypes.Codec, f CreateEncoderFunc) WriterOption

WithWriterAddEncoder add custom codec implementation to writer. It allows to set custom codecs implementations for custom and internal codecs.

If CreateEncoderFunc returns a writer implementing ResetableWriter, then the compression objects will be reused for this codec. This will reduce the load on the GC.

func WithWriterCheckRetryErrorFunction added in v3.42.0

func WithWriterCheckRetryErrorFunction(callback CheckErrorRetryFunction) WriterOption

WithWriterCheckRetryErrorFunction can override default error retry policy use CheckErrorRetryDecisionDefault for use default behavior for the error callback func must be fast and deterministic: always result same result for same error - it can be called few times for every error

Example
var db *ydb.Driver
writer, err := db.Topic().StartWriter(
	"",
	topicoptions.WithWriterCheckRetryErrorFunction(
		func(errInfo topicoptions.CheckErrorRetryArgs) topicoptions.CheckErrorRetryResult {
			// Retry for all transport errors
			if ydb.IsTransportError(errInfo.Error) {
				return topicoptions.CheckErrorRetryDecisionRetry
			}

			// and use default behavior for all other errors
			return topicoptions.CheckErrorRetryDecisionDefault
		}),
)
_, _ = writer, err

func WithWriterCodec added in v3.52.3

func WithWriterCodec(codec topictypes.Codec) WriterOption

WithWriterCodec disable codec auto select and force set codec for the write session

func WithWriterCodecAutoSelect added in v3.52.3

func WithWriterCodecAutoSelect() WriterOption

WithWriterCodecAutoSelect - auto select best codec for messages stream enabled by default if option enabled - send a batch of messages for every allowed codec (for prevent delayed bad codec accident) then from time to time measure all codecs and select codec with the smallest result messages size

func WithWriterCompressorCount added in v3.38.0

func WithWriterCompressorCount(num int) WriterOption

WithWriterCompressorCount set max count of goroutine for compress messages must be more zero

panic if num <= 0

func WithWriterLogContext added in v3.108.4

func WithWriterLogContext(ctx context.Context) WriterOption

WithWriterLogContext allows providing a context.Context instance which will be used in log/topic events.

func WithWriterMaxQueueLen added in v3.38.2

func WithWriterMaxQueueLen(num int) WriterOption

WithWriterMaxQueueLen set max len of queue for wait ack

Experimental: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#experimental

func WithWriterMessageMaxBytesSize added in v3.38.2

func WithWriterMessageMaxBytesSize(size int) WriterOption

WithWriterMessageMaxBytesSize set max body size of one message in bytes. Writer will return error in message will be more than the size.

func WithWriterPartitionID added in v3.52.3

func WithWriterPartitionID(partitionID int64) WriterOption

WithWriterPartitionID set direct partition id on write session level

func WithWriterProducerID added in v3.52.3

func WithWriterProducerID(producerID string) WriterOption

WithWriterProducerID set producer for write session

func WithWriterSessionMeta added in v3.52.3

func WithWriterSessionMeta(meta map[string]string) WriterOption

WithWriterSessionMeta set writer's session metadata

func WithWriterSetAutoCreatedAt added in v3.38.0

func WithWriterSetAutoCreatedAt(val bool) WriterOption

WithWriterSetAutoCreatedAt set messages CreatedAt by SDK enabled by default if enabled - Message.CreatedAt field must be zero

func WithWriterSetAutoSeqNo added in v3.38.0

func WithWriterSetAutoSeqNo(val bool) WriterOption

WithWriterSetAutoSeqNo set messages SeqNo by SDK enabled by default if enabled - Message.SeqNo field must be zero

func WithWriterStartTimeout added in v3.42.0

func WithWriterStartTimeout(timeout time.Duration) WriterOption

WithWriterStartTimeout mean timeout for connect to writer stream and work some time without errors

func WithWriterTrace added in v3.40.0

func WithWriterTrace(t trace.Topic) WriterOption

WithWriterTrace set tracer for the writer

func WithWriterUpdateTokenInterval added in v3.41.0

func WithWriterUpdateTokenInterval(interval time.Duration) WriterOption

WithWriterUpdateTokenInterval set time interval between send auth token to the server

func WithWriterWaitServerAck added in v3.52.3

func WithWriterWaitServerAck(wait bool) WriterOption

WithWriterWaitServerAck - when enabled every Write call wait ack from server for all messages from the call disabled by default. Make writer much slower, use only if you really need it.

Jump to

Keyboard shortcuts

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