Documentation ¶
Index ¶
- Constants
- type AddMapConfigInput
- type AttributeConfig
- type BitmapIndexOptions
- type CacheConfigHolder
- type CacheConfigInput
- type CacheConfigs
- type CacheDeserializedValues
- type Capacity
- type ClusterHotRestartStatus
- type ClusterMetadata
- type ClusterState
- type DataPersistenceConfig
- type DiskTierConfig
- type DurableExecutorServiceConfig
- type DurationConfig
- type EventJournalConfig
- type EvictionConfigHolder
- type EvictionPolicyType
- type ExecutorServiceConfig
- type ExecutorServices
- type HotRestartConfig
- type HotRestartState
- type InMemoryFormat
- type IndexConfig
- type IndexType
- type JetTerminateJob
- type JobAndSqlSummary
- type JobMetaData
- type ListenerConfigHolder
- type MCEvent
- type MCEventData
- type MCEventType
- type MapConfig
- type MapConfigs
- type MapStoreConfigHolder
- type MaxSizePolicyType
- type MemberPartitionState
- type MemberState
- type MemoryTierConfig
- type MergePolicyConfig
- type MerkleTreeConfig
- type MetadataPolicy
- type MultiMapConfig
- type MultiMapConfigs
- type NearCacheConfigHolder
- type NearCachePreloaderConfig
- type NodeState
- type PartitioningAttributeConfig
- type PredicateConfigHolder
- type QueryCacheConfigHolder
- type QueueConfigInput
- type QueueConfigs
- type QueueStoreConfigHolder
- type RaftGroupId
- type ReplicatedMapConfig
- type ReplicatedMapConfigs
- type ResourceDefinition
- type ScheduledExecutorServiceConfig
- type SqlSummary
- type TerminateMode
- type TieredStoreConfig
- type TimedExpiryPolicyFactoryConfig
- type TimedMemberState
- type TimedMemberStateWrapper
- type TopicConfig
- type TopicConfigs
- type UniqueKeyTransformation
- type UserCodeNamespaceConfig
- type WanReplicationRef
- type WanReplicationState
- type WanSyncRef
- type WanSyncType
Constants ¶
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 // nullable UserCodeNamespace string }
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 BitmapIndexOptions ¶
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 UserCodeNamespace string }
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 UserCodeNamespace string }
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 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 ¶
func (c ClusterHotRestartStatus) RestoreState() hazelcastv1alpha1.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 DiskTierConfig ¶
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 // nullable UserCodeNamespace string }
func DefaultAddDurableExecutorServiceInput ¶
func DefaultAddDurableExecutorServiceInput() *DurableExecutorServiceConfig
type DurationConfig ¶
type EventJournalConfig ¶
type EvictionConfigHolder ¶
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 // nullable UserCodeNamespace 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 HotRestartState ¶
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 JetTerminateJob ¶
type JetTerminateJob struct { JobId int64 TerminateMode TerminateMode LightJobCoordinator types.UUID }
type JobAndSqlSummary ¶
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 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) PublisherId ¶
func (MCEvent) WithMapName ¶
func (MCEvent) WithReason ¶
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 MapConfigs ¶
type MapConfigs struct {
Maps []AddMapConfigInput `xml:"map"`
}
type MapStoreConfigHolder ¶
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 MerkleTreeConfig ¶
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 // nullable UserCodeNamespace 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 PartitioningAttributeConfig ¶
type PartitioningAttributeConfig struct {
AttributeName string
}
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"` UserCodeNamespace string }
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 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 // nullable UserCodeNamespace 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 ResourceDefinition ¶
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 // nullable UserCodeNamespace string }
func DefaultAddScheduledExecutorServiceInput ¶
func DefaultAddScheduledExecutorServiceInput() *ScheduledExecutorServiceConfig
type SqlSummary ¶
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 // nullable UserCodeNamespace string }
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 UserCodeNamespaceConfig ¶
type UserCodeNamespaceConfig struct { Name string Resources []ResourceDefinition }
type WanReplicationRef ¶
type WanSyncRef ¶
type WanSyncRef struct { WanReplicationName string WanPublisherId string Type WanSyncType MapName string }
Source Files ¶
- attribute_config.go
- bitmap_index_options.go
- cache_config.go
- cache_config_holder.go
- capacity.go
- cluster_metadata.go
- data_persistence_config.go
- disk_tier_config.go
- duration_config.go
- enums.go
- event_journal_config.go
- eviction_config_holder.go
- executor_service_config.go
- hot_restart_config.go
- index_config.go
- job_and_sql_config.go
- listener_config_holder.go
- map_store_config_holder.go
- mc_event.go
- memory_tier_config.go
- merge_policy_config.go
- merkle_tree_config.go
- multimap_config.go
- near_cache_config_holder.go
- near_cache_preloader_config.go
- partitioning_attribute_config.go
- predicate_config_holder.go
- query_cache_config_holder.go
- queue_config.go
- queue_store_config_holder.go
- raft_group_id.go
- replicatedmap_config.go
- request_add_map_config.go
- resource_definition.go
- response_get_map_config.go
- tiered_store_config.go
- timed_expiry_policy_factory_config.go
- topic_config.go
- typed_member_state.go
- user_code_namespace_config.go
- wan_replication_ref.go
- wan_replication_state.go
- wan_sync.go