types

package
v0.0.0-...-c55d01b Latest Latest
Warning

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

Go to latest
Published: Apr 18, 2024 License: Apache-2.0 Imports: 6 Imported by: 0

Documentation

Index

Constants

View Source
const (
	WanReplicationStateReplicating = 0
	WanReplicationStatePaused      = 1
	WanReplicationStateStopped     = 2
)

manual

Variables

This section is empty.

Functions

This section is empty.

Types

type AddMapConfigInput

type AddMapConfigInput struct {
	Name              string `xml:"name,attr"`
	BackupCount       int32  `xml:"backup-count"`
	AsyncBackupCount  int32  `xml:"async-backup-count"`
	TimeToLiveSeconds int32  `xml:"time-to-live-seconds"`
	MaxIdleSeconds    int32  `xml:"max-idle-seconds"`
	// nullable
	EvictionConfig          EvictionConfigHolder
	ReadBackupData          bool
	CacheDeserializedValues string
	MergePolicy             string
	MergeBatchSize          int32
	InMemoryFormat          string `xml:"in-memory-format"`
	// nullable
	ListenerConfigs []ListenerConfigHolder
	// nullable
	PartitionLostListenerConfigs []ListenerConfigHolder
	StatisticsEnabled            bool
	// nullable
	SplitBrainProtectionName string
	// nullable
	MapStoreConfig MapStoreConfigHolder
	// nullable
	NearCacheConfig NearCacheConfigHolder
	// nullable
	WanReplicationRef WanReplicationRef
	// nullable
	IndexConfigs []IndexConfig
	// nullable
	AttributeConfigs []AttributeConfig
	// nullable
	QueryCacheConfigs []QueryCacheConfigHolder
	// nullable
	PartitioningStrategyClassName string
	// nullable
	PartitioningStrategyImplementation iserialization.Data
	// nullable
	HotRestartConfig HotRestartConfig
	// nullable
	EventJournalConfig EventJournalConfig
	// nullable
	MerkleTreeConfig      MerkleTreeConfig `xml:"merkle-tree"`
	MetadataPolicy        int32
	PerEntryStatsEnabled  bool
	TieredStoreConfig     TieredStoreConfig `xml:"tiered-store"`
	DataPersistenceConfig DataPersistenceConfig
}

func DefaultAddMapConfigInput

func DefaultAddMapConfigInput() *AddMapConfigInput

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type AttributeConfig

type AttributeConfig struct {
	Name               string
	ExtractorClassName string
}

type BitmapIndexOptions

type BitmapIndexOptions struct {
	UniqueKey               string
	UniqueKeyTransformation int32
}

type CacheConfigHolder

type CacheConfigHolder struct {
	Name                              string
	ManagerPrefix                     string
	UriString                         string
	BackupCount                       int32
	AsyncBackupCount                  int32
	InMemoryFormat                    string
	EvictionConfigHolder              EvictionConfigHolder
	WanReplicationRef                 WanReplicationRef
	KeyClassName                      string
	ValueClassName                    string
	CacheLoaderFactory                iserialization.Data
	CacheWriterFactory                iserialization.Data
	ExpiryPolicyFactory               iserialization.Data
	ReadThrough                       bool
	WriteThrough                      bool
	StoreByValue                      bool
	ManagementEnabled                 bool
	StatisticsEnabled                 bool
	HotRestartConfig                  HotRestartConfig
	EventJournalConfig                EventJournalConfig
	SplitBrainProtectionName          string
	ListenerConfigurations            []iserialization.Data
	MergePolicyConfig                 MergePolicyConfig
	DisablePerEntryInvalidationEvents bool
	CachePartitionLostListenerConfigs []ListenerConfigHolder
	MerkleTreeConfig                  MerkleTreeConfig
	DataPersistenceConfig             DataPersistenceConfig
}

type CacheConfigInput

type CacheConfigInput struct {
	Name                              string `xml:"name,attr"`
	BackupCount                       int32  `xml:"backup-count"`
	AsyncBackupCount                  int32  `xml:"async-backup-count"`
	StatisticsEnabled                 bool   `xml:"statistics-enabled"`
	ManagementEnabled                 bool
	ReadThrough                       bool
	WriteThrough                      bool
	MergePolicy                       string
	MergeBatchSize                    int32
	DisablePerEntryInvalidationEvents bool
	KeyType                           string `xml:"key-type"`
	ValueType                         string `xml:"value-type"`
	CacheLoaderFactory                string
	CacheWriterFactory                string
	CacheLoader                       string
	CacheWriter                       string
	InMemoryFormat                    InMemoryFormat `xml:"in-memory-format"`
	SplitBrainProtectionName          string
	PartitionLostListenerConfigs      []ListenerConfigHolder
	ExpiryPolicyFactoryClassName      string
	TimedExpiryPolicyFactoryConfig    TimedExpiryPolicyFactoryConfig
	CacheEntryListeners               []ListenerConfigHolder
	EvictionConfig                    EvictionConfigHolder
	WanReplicationRef                 WanReplicationRef
	EventJournalConfig                EventJournalConfig
	HotRestartConfig                  HotRestartConfig
	MerkleTreeConfig                  MerkleTreeConfig
	DataPersistenceConfig             DataPersistenceConfig
}

func DefaultCacheConfigInput

func DefaultCacheConfigInput() *CacheConfigInput

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type CacheConfigs

type CacheConfigs struct {
	Caches []CacheConfigInput `xml:"cache"`
}

type CacheDeserializedValues

type CacheDeserializedValues string
const (
	CacheDeserializedValuesNever     CacheDeserializedValues = "NEVER"
	CacheDeserializedValuesIndexOnly CacheDeserializedValues = "INDEX_ONLY"
	CacheDeserializedValuesAlways    CacheDeserializedValues = "ALWAYS"
)

type Capacity

type Capacity struct {
	Value int64  `xml:"value,attr"`
	Unit  string `xml:"unit,attr"`
}

type ClusterHotRestartStatus

type ClusterHotRestartStatus struct {
	HotRestartStatus              string `json:"hotRestartStatus"`
	RemainingValidationTimeMillis int64  `json:"remainingValidationTimeMillis"`
	RemainingDataLoadTimeMillis   int64  `json:"remainingDataLoadTimeMillis"`
}

func (ClusterHotRestartStatus) RemainingDataLoadTimeSec

func (c ClusterHotRestartStatus) RemainingDataLoadTimeSec() int64

func (ClusterHotRestartStatus) RemainingValidationTimeSec

func (c ClusterHotRestartStatus) RemainingValidationTimeSec() int64

func (ClusterHotRestartStatus) RestoreState

type ClusterMetadata

type ClusterMetadata struct {
	CurrentState  ClusterState
	MemberVersion string
	JetVersion    string
	ClusterTime   int64
}

type ClusterState

type ClusterState int32
const (
	ClusterStateActive ClusterState = iota
	ClusterStateNoMigration
	ClusterStateFrozen
	ClusterStatePassive
	ClusterStateInTransition
)

type DataPersistenceConfig

type DataPersistenceConfig struct {
	Enabled bool
	Fsync   bool
}

type DiskTierConfig

type DiskTierConfig struct {
	Enabled    bool   `xml:"enabled,attr"`
	DeviceName string `xml:"device-name,attr"`
}

type DurableExecutorServiceConfig

type DurableExecutorServiceConfig struct {
	Name              string `xml:"name,attr"`
	PoolSize          int32  `xml:"pool-size"`
	Durability        int32  `xml:"durability"`
	Capacity          int32  `xml:"capacity"`
	StatisticsEnabled bool
	// nullable
	SplitBrainProtectionName string
}

func DefaultAddDurableExecutorServiceInput

func DefaultAddDurableExecutorServiceInput() *DurableExecutorServiceConfig

type DurationConfig

type DurationConfig struct {
	DurationAmount int64
	TimeUnit       int32
}

type EventJournalConfig

type EventJournalConfig struct {
	Enabled           bool
	Capacity          int32
	TimeToLiveSeconds int32
}

type EvictionConfigHolder

type EvictionConfigHolder struct {
	Size                int32
	MaxSizePolicy       string
	EvictionPolicy      string
	ComparatorClassName string
	Comparator          iserialization.Data
}

type EvictionPolicyType

type EvictionPolicyType string

+kubebuilder:validation:Enum=NONE;LRU;LFU;RANDOM

const (
	// Least recently used entries will be removed.
	EvictionPolicyLRU EvictionPolicyType = "LRU"

	// Least frequently used entries will be removed.
	EvictionPolicyLFU EvictionPolicyType = "LFU"

	// No eviction.
	EvictionPolicyNone EvictionPolicyType = "NONE"

	// Randomly selected entries will be removed.
	EvictionPolicyRandom EvictionPolicyType = "RANDOM"
)

type ExecutorServiceConfig

type ExecutorServiceConfig struct {
	Name              string `xml:"name,attr"`
	PoolSize          int32  `xml:"pool-size"`
	QueueCapacity     int32  `xml:"queue-capacity"`
	StatisticsEnabled bool
	// nullable
	SplitBrainProtectionName string
}

func DefaultAddExecutorServiceInput

func DefaultAddExecutorServiceInput() *ExecutorServiceConfig

type ExecutorServices

type ExecutorServices struct {
	Basic     []ExecutorServiceConfig          `xml:"executor-service"`
	Durable   []DurableExecutorServiceConfig   `xml:"durable-executor-service"`
	Scheduled []ScheduledExecutorServiceConfig `xml:"scheduled-executor-service"`
}

type HotRestartConfig

type HotRestartConfig struct {
	Enabled bool
	Fsync   bool
}

type HotRestartState

type HotRestartState struct {
	BackupTaskState     string `json:"backupTaskState"`
	BackupTaskCompleted int32  `json:"backupTaskCompleted"`
	BackupTaskTotal     int32  `json:"backupTaskTotal"`
	IsHotBackupEnabled  bool   `json:"isHotBackupEnabled"`
	BackupDirectory     string `json:"backupDirectory"`
}

type InMemoryFormat

type InMemoryFormat string
const (
	InMemoryFormatBinary InMemoryFormat = "BINARY"
	InMemoryFormatObject InMemoryFormat = "OBJECT"
	InMemoryFormatNative InMemoryFormat = "NATIVE"
)

type IndexConfig

type IndexConfig struct {
	Name               string
	Type               int32
	Attributes         []string
	BitmapIndexOptions BitmapIndexOptions
}

type IndexType

type IndexType int32
const (
	IndexTypeSorted IndexType = 0
	IndexTypeHash   IndexType = 1
	IndexTypeBitmap IndexType = 2
)

type JetTerminateJob

type JetTerminateJob struct {
	JobId               int64
	TerminateMode       TerminateMode
	LightJobCoordinator types.UUID
}

type JobAndSqlSummary

type JobAndSqlSummary struct {
	LightJob        bool
	JobId           int64
	ExecutionId     int64
	NameOrId        string
	Status          int32
	SubmissionTime  int64
	CompletionTime  int64
	FailureText     string
	SqlSummary      SqlSummary
	SuspensionCause string
}

type JobMetaData

type JobMetaData struct {
	SessionId     types.UUID
	JarOnMember   bool
	FileName      string
	Sha256Hex     string
	SnapshotName  string
	JobName       string
	MainClass     string
	JobParameters []string
}

func DefaultExistingJarJobMetaData

func DefaultExistingJarJobMetaData(jobName string, jarName string) JobMetaData

type ListenerConfigHolder

type ListenerConfigHolder struct {
	ListenerType           int32
	ListenerImplementation iserialization.Data
	ClassName              string
	IncludeValue           bool
	Local                  bool
}

type MCEvent

type MCEvent struct {
	Timestamp int64
	Type      MCEventType
	DataJson  string
	Data      MCEventData
}

func NewMCEvent

func NewMCEvent(timestamp int64, eventType MCEventType, dataJson string) MCEvent

func (MCEvent) MapName

func (d MCEvent) MapName() string

func (MCEvent) PublisherId

func (d MCEvent) PublisherId() string

func (MCEvent) Reason

func (d MCEvent) Reason() string

func (MCEvent) UUID

func (d MCEvent) UUID() string

func (MCEvent) WithMapName

func (d MCEvent) WithMapName(m string) MCEvent

func (MCEvent) WithReason

func (d MCEvent) WithReason(r string) MCEvent

type MCEventData

type MCEventData map[string]interface{}

type MCEventType

type MCEventType int32
const (
	WanConsistencyCheckStarted MCEventType = iota + 1
	WanConsistencyCheckFinished
	WanSyncStarted
	WanSyncFinishedFull
	WanConsistencyCheckIgnored
	WanSyncProgressUpdate
	WanSyncFinishedMerkle
	WanConfigurationAdded
	AddWanConfigurationIgnored
	WanSyncIgnored
	WanConfigurationExtended
)

func (MCEventType) IsDone

func (e MCEventType) IsDone() bool

func (MCEventType) IsError

func (e MCEventType) IsError() bool

func (MCEventType) IsInProgress

func (e MCEventType) IsInProgress() bool

func (MCEventType) IsWanSync

func (e MCEventType) IsWanSync() bool

type MapConfig

type MapConfig struct {
	InMemoryFormat    int32
	BackupCount       int32
	AsyncBackupCount  int32
	TimeToLiveSeconds int32
	MaxIdleSeconds    int32
	MaxSize           int32
	MaxSizePolicy     int32
	ReadBackupData    bool
	EvictionPolicy    int32
	MergePolicy       string
	Indexes           []IndexConfig
	TieredStoreConfig TieredStoreConfig
}

type MapConfigs

type MapConfigs struct {
	Maps []AddMapConfigInput `xml:"map"`
}

type MapStoreConfigHolder

type MapStoreConfigHolder struct {
	Enabled               bool
	WriteCoalescing       bool
	WriteDelaySeconds     int32
	WriteBatchSize        int32
	ClassName             string
	Implementation        iserialization.Data
	FactoryClassName      string
	FactoryImplementation iserialization.Data
	Properties            map[string]string
	InitialLoadMode       string
}

type MaxSizePolicyType

type MaxSizePolicyType string

+kubebuilder:validation:Enum=PER_NODE;PER_PARTITION;USED_HEAP_SIZE;USED_HEAP_PERCENTAGE;FREE_HEAP_SIZE;FREE_HEAP_PERCENTAGE;USED_NATIVE_MEMORY_SIZE;USED_NATIVE_MEMORY_PERCENTAGE;FREE_NATIVE_MEMORY_SIZE;FREE_NATIVE_MEMORY_PERCENTAGE

const (
	// Maximum number of map entries in each cluster member.
	// You cannot set the max-size to a value lower than the partition count (which is 271 by default).
	MaxSizePolicyPerNode MaxSizePolicyType = "PER_NODE"

	// Maximum number of map entries within each partition.
	MaxSizePolicyPerPartition MaxSizePolicyType = "PER_PARTITION"

	// Maximum used heap size percentage per map for each Hazelcast instance.
	// If, for example, JVM is configured to have 1000 MB and this value is 10, then the map entries will be evicted when used heap size
	// exceeds 100 MB. It does not work when "in-memory-format" is set to OBJECT.
	MaxSizePolicyUsedHeapPercentage MaxSizePolicyType = "USED_HEAP_PERCENTAGE"

	// Maximum used heap size in megabytes per map for each Hazelcast instance. It does not work when "in-memory-format" is set to OBJECT.
	MaxSizePolicyUsedHeapSize MaxSizePolicyType = "USED_HEAP_SIZE"

	// Minimum free heap size percentage for each Hazelcast instance. If, for example, JVM is configured to
	// have 1000 MB and this value is 10, then the map entries will be evicted when free heap size is below 100 MB.
	MaxSizePolicyFreeHeapPercentage MaxSizePolicyType = "FREE_HEAP_PERCENTAGE"

	// Minimum free heap size in megabytes for each Hazelcast instance.
	MaxSizePolicyFreeHeapSize MaxSizePolicyType = "FREE_HEAP_SIZE"

	// Maximum used native memory size in megabytes per map for each Hazelcast instance. It is available only in
	// Hazelcast Enterprise HD.
	MaxSizePolicyUsedNativeMemorySize MaxSizePolicyType = "USED_NATIVE_MEMORY_SIZE"

	// Maximum used native memory size percentage per map for each Hazelcast instance. It is available only in
	// Hazelcast Enterprise HD.
	MaxSizePolicyUsedNativeMemoryPercentage MaxSizePolicyType = "USED_NATIVE_MEMORY_PERCENTAGE"

	// Minimum free native memory size in megabytes for each Hazelcast instance. It is available only in
	// Hazelcast Enterprise HD.
	MaxSizePolicyFreeNativeMemorySize MaxSizePolicyType = "FREE_NATIVE_MEMORY_SIZE"

	// Minimum free native memory size percentage for each Hazelcast instance. It is available only in
	// Hazelcast Enterprise HD.
	MaxSizePolicyFreeNativeMemoryPercentage MaxSizePolicyType = "FREE_NATIVE_MEMORY_PERCENTAGE"
)

type MemberPartitionState

type MemberPartitionState struct {
	Partitions []int32 `json:"partitions"`
}

type MemberState

type MemberState struct {
	Address                 string                  `json:"address"`
	Uuid                    string                  `json:"uuid"`
	Name                    string                  `json:"name"`
	NodeState               NodeState               `json:"nodeState"`
	HotRestartState         HotRestartState         `json:"hotRestartState"`
	ClusterHotRestartStatus ClusterHotRestartStatus `json:"clusterHotRestartStatus"`
}

type MemoryTierConfig

type MemoryTierConfig struct {
	Capacity Capacity `xml:"capacity"`
}

type MergePolicyConfig

type MergePolicyConfig struct {
	Policy    string
	BatchSize int32
}

type MerkleTreeConfig

type MerkleTreeConfig struct {
	Enabled    bool  `xml:"enabled"`
	Depth      int32 `xml:"depth"`
	EnabledSet bool
}

type MetadataPolicy

type MetadataPolicy int32
const (
	MetadataPolicyCreateOnUpdate MetadataPolicy = 0
	MetadataPolicyOff            MetadataPolicy = 1
)

type MultiMapConfig

type MultiMapConfig struct {
	Name              string `xml:"name,attr"`
	CollectionType    string `xml:"value-collection-type"`
	BackupCount       int32  `xml:"backup-count"`
	AsyncBackupCount  int32  `xml:"async-backup-count"`
	Binary            bool   `xml:"binary"`
	MergePolicy       string
	MergeBatchSize    int32
	StatisticsEnabled bool
	// nullable
	ListenerConfigs []ListenerConfigHolder
	// nullable
	SplitBrainProtectionName string
}

func DefaultMultiMapConfigInput

func DefaultMultiMapConfigInput() *MultiMapConfig

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type MultiMapConfigs

type MultiMapConfigs struct {
	MultiMaps []MultiMapConfig `xml:"multimap"`
}

type NearCacheConfigHolder

type NearCacheConfigHolder struct {
	Name                 string
	InMemoryFormat       string
	SerializeKeys        bool
	InvalidateOnChange   bool
	TimeToLiveSeconds    int32
	MaxIdleSeconds       int32
	EvictionConfigHolder EvictionConfigHolder
	CacheLocalEntries    bool
	LocalUpdatePolicy    string
	PreloaderConfig      NearCachePreloaderConfig
}

type NearCachePreloaderConfig

type NearCachePreloaderConfig struct {
	Enabled                  bool
	Directory                string
	StoreInitialDelaySeconds int32
	StoreIntervalSeconds     int32
}

type NodeState

type NodeState struct {
	State         string `json:"nodeState"`
	MemberVersion string `json:"memberVersion"`
}

type PredicateConfigHolder

type PredicateConfigHolder struct {
	ClassName      string
	Sql            string
	Implementation iserialization.Data
}

type QueryCacheConfigHolder

type QueryCacheConfigHolder struct {
	BatchSize             int32
	BufferSize            int32
	DelaySeconds          int32
	IncludeValue          bool
	Populate              bool
	Coalesce              bool
	InMemoryFormat        string
	Name                  string
	PredicateConfigHolder PredicateConfigHolder
	EvictionConfigHolder  EvictionConfigHolder
	ListenerConfigs       []ListenerConfigHolder
	IndexConfigs          []IndexConfig
}

type QueueConfigInput

type QueueConfigInput struct {
	Name                        string `xml:"name,attr"`
	ListenerConfigs             []ListenerConfigHolder
	BackupCount                 int32 `xml:"backup-count"`
	AsyncBackupCount            int32 `xml:"async-backup-count"`
	MaxSize                     int32 `xml:"max-size"`
	EmptyQueueTtl               int32 `xml:"empty-queue-ttl"`
	StatisticsEnabled           bool  `xml:"statistics-enabled"`
	SplitBrainProtectionName    string
	QueueStoreConfig            QueueStoreConfigHolder
	MergePolicy                 string
	MergeBatchSize              int32
	PriorityComparatorClassName string `xml:"priority-comparator-class-name"`
}

func DefaultQueueConfigInput

func DefaultQueueConfigInput() *QueueConfigInput

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type QueueConfigs

type QueueConfigs struct {
	Queues []QueueConfigInput `xml:"queue"`
}

type QueueStoreConfigHolder

type QueueStoreConfigHolder struct {
	ClassName             string
	FactoryClassName      string
	Implementation        iserialization.Data
	FactoryImplementation iserialization.Data
	Properties            map[string]string
	Enabled               bool
}

type RaftGroupId

type RaftGroupId struct {
	Name string
	Seed int64
	Id   int64
}

type ReplicatedMapConfig

type ReplicatedMapConfig struct {
	Name              string `xml:"name,attr"`
	InMemoryFormat    string `xml:"in-memory-format"`
	AsyncFillup       bool   `xml:"async-fillup"`
	MergePolicy       string
	MergeBatchSize    int32
	StatisticsEnabled bool
	// nullable
	ListenerConfigs []ListenerConfigHolder
	// nullable
	SplitBrainProtectionName string
}

func DefaultReplicatedMapConfigInput

func DefaultReplicatedMapConfigInput() *ReplicatedMapConfig

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type ReplicatedMapConfigs

type ReplicatedMapConfigs struct {
	ReplicatedMaps []ReplicatedMapConfig `xml:"replicatedmap"`
}

type ScheduledExecutorServiceConfig

type ScheduledExecutorServiceConfig struct {
	Name              string `xml:"name,attr"`
	PoolSize          int32  `xml:"pool-size"`
	Durability        int32  `xml:"durability"`
	Capacity          int32  `xml:"capacity"`
	CapacityPolicy    string `xml:"capacity-policy"`
	StatisticsEnabled bool
	MergePolicy       string
	MergeBatchSize    int32
	// nullable
	SplitBrainProtectionName string
}

func DefaultAddScheduledExecutorServiceInput

func DefaultAddScheduledExecutorServiceInput() *ScheduledExecutorServiceConfig

type SqlSummary

type SqlSummary struct {
	Query     string
	Unbounded bool
}

type TerminateMode

type TerminateMode int32
const (
	RestartGracefully TerminateMode = iota
	RestartForcefully
	SuspendGracefully
	SuspendForcefully
	CancelGracefully
	CancelForcefully
)

type TieredStoreConfig

type TieredStoreConfig struct {
	Enabled          bool             `xml:"enabled,attr"`
	MemoryTierConfig MemoryTierConfig `xml:"memory-tier"`
	DiskTierConfig   DiskTierConfig   `xml:"disk-tier"`
}

type TimedExpiryPolicyFactoryConfig

type TimedExpiryPolicyFactoryConfig struct {
	ExpiryPolicyType int32
	DurationConfig   DurationConfig
}

type TimedMemberState

type TimedMemberState struct {
	MemberState          MemberState          `json:"memberState"`
	MemberPartitionState MemberPartitionState `json:"memberPartitionState"`
	Master               bool                 `json:"master"`
}

type TimedMemberStateWrapper

type TimedMemberStateWrapper struct {
	TimedMemberState TimedMemberState `json:"timedMemberState"`
}

type TopicConfig

type TopicConfig struct {
	Name                  string `xml:"name,attr"`
	GlobalOrderingEnabled bool   `xml:"global-ordering-enabled"`
	MultiThreadingEnabled bool   `xml:"multi-threading-enabled"`
	StatisticsEnabled     bool   `xml:"statistics-enabled"`
	//nullable
	ListenerConfigs []ListenerConfigHolder
}

func DefaultTopicConfigInput

func DefaultTopicConfigInput() *TopicConfig

Default values are explicitly written for all fields that are not nullable even though most are the same with the default values in Go.

type TopicConfigs

type TopicConfigs struct {
	Topics []TopicConfig `xml:"topic"`
}

type UniqueKeyTransformation

type UniqueKeyTransformation int32
const (
	UniqueKeyTransformationObject UniqueKeyTransformation = 0
	UniqueKeyTransformationLong   UniqueKeyTransformation = 1
	UniqueKeyTransformationRaw    UniqueKeyTransformation = 2
)

type WanReplicationRef

type WanReplicationRef struct {
	Name                 string
	MergePolicyClassName string
	Filters              []string
	RepublishingEnabled  bool
}

type WanReplicationState

type WanReplicationState = byte

manual

type WanSyncRef

type WanSyncRef struct {
	WanReplicationName string
	WanPublisherId     string
	Type               WanSyncType
	MapName            string
}

type WanSyncType

type WanSyncType int8
const (
	AllMaps WanSyncType = iota
	SingleMap
)

Jump to

Keyboard shortcuts

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