Documentation ¶
Index ¶
- type Archives
- type CacheDetail
- type CacheDetails
- type CachePartitionDetail
- type CachePartitionDetails
- type CacheStoreDetail
- type CacheStoreDetails
- type CacheSummaries
- type CacheSummaryDetail
- type ChannelDetails
- type ChannelStats
- type Cluster
- type DefaultDependency
- type DepartedMembers
- type Description
- type Distributions
- type ElasticData
- type ElasticDataValues
- type Executor
- type Executors
- type FederationDescription
- type FederationSummaries
- type FederationSummary
- type GenericDetails
- type HTTPSessionSummaries
- type HTTPSessionSummary
- type HeadStats
- type HeadsResult
- type HealthMonitoring
- type HealthSummaries
- type HealthSummary
- type HealthSummaryShort
- type ItemLinks
- type Link
- type Links
- type Machine
- type Member
- type Members
- type NetworkStats
- type NetworkStatsDetails
- type Ownership
- type PartitionOwnership
- type PersistenceCoordinator
- type ProxiesSummary
- type ProxyConnection
- type ProxyConnections
- type ProxySummary
- type Reporter
- type Reporters
- type ServiceCache
- type ServiceCaches
- type ServiceMemberDetail
- type ServiceMemberDetails
- type ServiceStorageSummary
- type ServiceSummary
- type ServicesStorageSummaries
- type ServicesSummaries
- type SingleStatusValue
- type Snapshots
- type StatsSummary
- type StatusValues
- type StorageDetail
- type StorageDetails
- type SubscriberChannelStats
- type SubscriberGroupChannelStats
- type TopicDetail
- type TopicDetails
- type TopicsMemberDetail
- type TopicsMemberDetails
- type TopicsSubscriberDetail
- type TopicsSubscriberDetails
- type TopicsSubscriberGroupDetail
- type TopicsSubscriberGroups
- type ViewCacheDetail
- type ViewCacheDetails
- type ViewCacheSummaries
- type ViewCacheSummaryDetail
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type Archives ¶
type Archives struct {
Snapshots []string `json:"archives"`
}
Archives contains archived snapshots.
type CacheDetail ¶
type CacheDetail struct { NodeID string `json:"nodeId"` Tier string `json:"tier"` UnitsBytes int64 `json:"unitsBytes"` Units int64 `json:"units"` UnitFactor int64 `json:"unitFactor"` CacheSize int32 `json:"size"` TotalPuts int64 `json:"totalPuts"` TotalGets int64 `json:"totalGets"` TotalRemoves int64 `json:"removeCount"` TotalClears int64 `json:"clearCount"` CacheHits int64 `json:"cacheHits"` CacheMisses int64 `json:"cacheMisses"` Evictions int64 `json:"evictionCount"` StoreReads int64 `json:"storeReads"` StoreWrites int64 `json:"storeWrites"` StoreFailures int64 `json:"storeFailures"` LocksGranted int64 `json:"locksGranted"` LocksPending int64 `json:"locksPending"` ListenerRegistrations int64 `json:"listenerRegistrations"` ListenerKeyCount int64 `json:"listenerKeyCount"` ListenerFilterCount int64 `json:"listenerFilterCount"` MaxQueryDurationMillis int64 `json:"maxQueryDurationMillis"` MaxQueryDescription string `json:"maxQueryDescription"` NonOptimizedQueryAverageMillis float64 `json:"nonOptimizedQueryAverageMillis"` OptimizedQueryAverageMillis float64 `json:"optimizedQueryAverageMillis"` IndexTotalUnits int64 `json:"indexTotalUnits"` IndexingTotalMillis int64 `json:"indexingTotalMillis"` IndexInfo []string `json:"indexInfo"` }
CacheDetail contains individual cache details for a cache, tier and node.
type CacheDetails ¶
type CacheDetails struct {
Details []CacheDetail `json:"items"`
}
CacheDetails contains cache details.
type CachePartitionDetail ¶
type CachePartitionDetail struct { PartitionID int32 `json:"partitionId"` Count int32 `json:"count"` TotalSize int64 `json:"totalSize"` MemberID int32 `json:"memberId"` MaxEntrySize int32 `json:"maxEntrySize"` }
CachePartitionDetail contains individual partition details for a cache.
type CachePartitionDetails ¶
type CachePartitionDetails struct {
Details []CachePartitionDetail `json:"reportPartitionStats"`
}
CachePartitionDetails contains cache partition details.
type CacheStoreDetail ¶
type CacheStoreDetail struct { NodeID string `json:"nodeId"` Tier string `json:"tier"` QueueSize int64 `json:"queueSize"` StoreAverageBatchSize int64 `json:"storeAverageBatchSize"` StoreWrites int64 `json:"storeWrites"` StoreAverageWriteMillis int64 `json:"storeAverageWriteMillis"` StoreWriteMillis int64 `json:"storeWriteMillis"` StoreFailures int64 `json:"storeFailures"` StoreReads int64 `json:"storeReads"` StoreAverageReadMillis int64 `json:"storeAverageReadMillis"` StoreReadMillis int64 `json:"storeReadMillis"` PersistenceType string `json:"persistenceType"` }
CacheStoreDetail contains the cache store information.
type CacheStoreDetails ¶
type CacheStoreDetails struct {
Details []CacheStoreDetail `json:"items"`
}
CacheStoreDetails contains cache details.
type CacheSummaries ¶
type CacheSummaries struct {
Caches []CacheSummaryDetail `json:"items"`
}
CacheSummaries contains cache summary details.
type CacheSummaryDetail ¶
type CacheSummaryDetail struct { ServiceName string `json:"service"` CacheName string `json:"name"` CacheSize int32 `json:"size"` UnitsBytes int64 `json:"unitsBytes"` TotalPuts int64 `json:"totalPuts"` TotalGets int64 `json:"totalGets"` TotalRemoves int64 `json:"removeCount"` CacheHits int64 `json:"cacheHits"` CacheMisses int64 `json:"cacheMisses"` TotalEvictions int64 `json:"evictionCount"` }
CacheSummaryDetail contains a summary of cache details.
type ChannelDetails ¶
type ChannelDetails struct {
Details map[string]interface{} `json:"channels"`
}
ChannelDetails contains all channels details.
type ChannelStats ¶
type ChannelStats struct { Channel int64 `json:"channel"` PublishedCount int64 `json:"publishedCount"` PublishedFifteenMinuteRate float64 `json:"publishedFifteenMinuteRate"` PublishedFiveMinuteRate float64 `json:"publishedFiveMinuteRate"` PublishedMeanRate float64 `json:"publishedMeanRate"` PublishedOneMinuteRate float64 `json:"publishedOneMinuteRate"` Tail string `json:"tail"` }
ChannelStats contains statistics summaries for Channels.
type Cluster ¶
type Cluster struct { ClusterName string `json:"clusterName"` ClusterSize int `json:"clusterSize"` LicenseMode string `json:"licenseMode"` Version string `json:"version"` Running bool `json:"running"` MembersDepartureCount int `json:"membersDepartureCount"` MembersDeparted []string `json:"membersDeparted"` }
Cluster is a structure to display cluster details for 'describe cluster'.
type DefaultDependency ¶
DefaultDependency holds the default dependencies for starting a Cache server.
type DepartedMembers ¶
type DepartedMembers struct { NodeID string `json:"nodeId"` TimeStamp string `json:"timeStamp"` Address string `json:"address"` MachineID string `json:"machineID"` Location string `json:"location"` Role string `json:"role"` }
DepartedMembers contains a decoded departed member from cluster.
type Description ¶
type Description struct {
Description string `json:"description"`
}
Description contains description for an item.
type Distributions ¶
type Distributions struct {
ScheduledDistributions string `json:"scheduledDistributions"`
}
Distributions contains scheduled distributions.
type ElasticData ¶
type ElasticData struct { NodeID string `json:"nodeId"` Name string `json:"name"` Type string `json:"type"` FileCount int32 `json:"fileCount"` MaxJournalFilesNumber int32 `json:"maxJournalFilesNumber"` CurrentCollectorLoadFactor float32 `json:"currentCollectorLoadFactor"` HighestLoadFactor float32 `json:"highestLoadFactor"` CompactionCount int64 `json:"compactionCount"` ExhaustiveCompactionCount int64 `json:"exhaustiveCompactionCount"` MaxFileSize int64 `json:"maxFileSize"` TotalDataSize int64 `json:"totalDataSize"` }
ElasticData contains elastic data information for a node and type.
type ElasticDataValues ¶
type ElasticDataValues struct {
ElasticData []ElasticData `json:"items"`
}
ElasticDataValues contains elastic data details.
type Executor ¶
type Executor struct { Name string `json:"name"` ID string `json:"id"` Description string `json:"description"` MemberID string `json:"memberId"` State string `json:"state"` Location string `json:"location"` TasksInProgressCount int64 `json:"tasksInProgressCount"` TasksCompletedCount int64 `json:"tasksCompletedCount"` TasksRejectedCount int64 `json:"tasksRejectedCount"` MemberCount int32 `json:"memberCount"` TraceLogging bool `json:"traceLogging"` }
Executor contains individual executor information.
type Executors ¶
type Executors struct {
Executors []Executor `json:"items"`
}
Executors contains multiple Executor objects.
type FederationDescription ¶
type FederationDescription struct { NodeID string `json:"nodeId"` State string `json:"state"` TotalMsgSent int64 `json:"totalMsgSent"` TotalBytesSent int64 `json:"totalBytesSent"` TotalRecordsSent int64 `json:"totalRecordsSent"` MsgNetworkRoundTripTimePercentileMillis int64 `json:"msgNetworkRoundTripTimePercentileMillis"` MsgApplyTimePercentileMillis int64 `json:"msgApplyTimePercentileMillis"` RecordBacklogDelayTimePercentileMillis int64 `json:"recordBacklogDelayTimePercentileMillis"` ReplicateAllPercentComplete int64 `json:"replicateAllPercentComplete"` ReplicateAllTotalTime int64 `json:"replicateAllTotalTime"` CurrentBandwidth float64 `json:"currentBandwidth"` TotalMsgReceived int64 `json:"totalMsgReceived"` // incoming TotalBytesReceived int64 `json:"totalBytesReceived"` TotalRecordsReceived int64 `json:"totalRecordsReceived"` CurrentConnectionCount int32 `json:"currentConnectionCount"` // additional replicate all stats only available in 21.12.2+ or 14.1.1. FP1 ReplicateAllPartitionCount int64 `json:"replicateAllPartitionCount"` ReplicateAllPartitionErrorCount int64 `json:"replicateAllPartitionErrorCount"` TotalReplicateAllPartitionsUnacked int64 `json:"totalReplicateAllPartitionsUnacked"` TotalRetryResponses int64 `json:"totalRetryResponses"` // addition mapMembers from 14.1.2+ MapMembers map[string]string `json:"mapMembers"` }
FederationDescription contains federation description details.
type FederationSummaries ¶
type FederationSummaries struct {
Services []FederationSummary `json:"items"`
}
FederationSummaries contains an array of FederationSummary.
type FederationSummary ¶
type FederationSummary struct { ServiceName string `json:"serviceName"` ParticipantName string `json:"participantName"` State []string `json:"state"` Member []string `json:"member"` TotalMsgSent StatsSummary `json:"totalMsgSent"` TotalBytesSent StatsSummary `json:"totalBytesSent"` TotalRecordsSent StatsSummary `json:"totalRecordsSent"` MsgNetworkRoundTripTimePercentileMillis StatsSummary `json:"msgNetworkRoundTripTimePercentileMillis"` MsgApplyTimePercentileMillis StatsSummary `json:"msgApplyTimePercentileMillis"` RecordBacklogDelayTimePercentileMillis StatsSummary `json:"recordBacklogDelayTimePercentileMillis"` ReplicateAllPercentComplete StatsSummary `json:"replicateAllPercentComplete"` ReplicateAllTotalTime StatsSummary `json:"replicateAllTotalTime"` CurrentBandwidth StatsSummary `json:"currentBandwidth"` TotalMsgReceived StatsSummary `json:"totalMsgReceived"` // incoming TotalBytesReceived StatsSummary `json:"totalBytesReceived"` TotalRecordsReceived StatsSummary `json:"totalRecordsReceived"` CurrentConnectionCount StatsSummary `json:"currentConnectionCount"` // additional replicate all stats only available in 21.12.2+ or 14.1.1. FP1 ReplicateAllPartitionCount StatsSummary `json:"replicateAllPartitionCount"` ReplicateAllPartitionErrorCount StatsSummary `json:"replicateAllPartitionErrorCount"` TotalReplicateAllPartitionsUnacked StatsSummary `json:"totalReplicateAllPartitionsUnacked"` }
FederationSummary contains Federation summary details for a service and participant.
type GenericDetails ¶
type GenericDetails struct {
Details []interface{} `json:"items"`
}
GenericDetails contains a slice of generic Json structures.
type HTTPSessionSummaries ¶
type HTTPSessionSummaries struct {
HTTPSessions []HTTPSessionSummary `json:"items"`
}
HTTPSessionSummaries contains an array of Coherence*Web Sessions.
type HTTPSessionSummary ¶
type HTTPSessionSummary struct { NodeID string `json:"nodeId"` AppID string `json:"appId"` Type string `json:"type"` SessionCacheName string `json:"sessionCacheName"` OverflowCacheName string `json:"overflowCacheName"` SessionTimeout int32 `json:"sessionTimeout"` SessionAverageSize int32 `json:"sessionAverageSize"` ReapedSessionsTotal int64 `json:"reapedSessionsTotal"` AverageReapDuration int64 `json:"averageReapDuration"` LastReapDuration int64 `json:"lastReapDuration"` SessionUpdates int64 `json:"sessionUpdates"` // calculated SessionAverageTotal int64 TotalReapDuration int64 MemberCount int32 }
HTTPSessionSummary contains a summary of Coherence*Web Sessions.
type HeadsResult ¶
type HeadsResult struct {
Channels map[string]interface{} `json:"heads"`
}
HeadsResult contains raw results from retrieve heads.
type HealthMonitoring ¶
type HealthMonitoring struct { Endpoint string `json:"endpoint"` NodeID string `json:"nodeID"` Member string `json:"member"` Ready string `json:"ready"` Started string `json:"started"` Live string `json:"live"` Safe string `json:"safe"` }
HealthMonitoring contains individual health monitoring details.
type HealthSummaries ¶
type HealthSummaries struct {
Summaries []HealthSummary `json:"items"`
}
HealthSummaries contains and array of HealthSummary.
type HealthSummary ¶
type HealthSummary struct { Type string `json:"type"` SubType string `json:"subType"` Name string `json:"name"` Description string `json:"description"` NodeID string `json:"nodeId"` ClassName string `json:"className"` MemberHealthCheck bool `json:"memberHealthCheck"` Ready bool `json:"ready"` Started bool `json:"started"` Live bool `json:"live"` Safe bool `json:"safe"` }
HealthSummary contains individual health summary details.
type HealthSummaryShort ¶
type HealthSummaryShort struct { TotalCount int32 SubType string Name string Description string ReadyCount int32 StartedCount int32 LiveCount int32 SafeCount int32 }
HealthSummaryShort contains summarised health across all nodes for a SubType and Name.
type ItemLinks ¶
type ItemLinks struct {
Links []Links `json:"items"`
}
ItemLinks contains links for an item.
type Links ¶
type Links struct {
Links []Link `json:"links"`
}
Links contains any links returned via HTTP.
type Machine ¶
type Machine struct { MachineName string `json:"operationStatus"` AvailableProcessors int32 `json:"availableProcessors"` SystemLoadAverage float32 `json:"systemLoadAverage"` // check first SystemCPULoad interface{} `json:"systemCpuLoad"` // check second TotalPhysicalMemorySize int64 `json:"totalPhysicalMemorySize"` FreePhysicalMemorySize int64 `json:"freePhysicalMemorySize"` Arch string `json:"arch"` Name string `json:"name"` Version string `json:"version"` }
Machine contains machine details.
type Member ¶
type Member struct { NodeID string `json:"nodeId"` UnicastAddress string `json:"unicastAddress"` UnicastPort int32 `json:"unicastPort"` RoleName string `json:"roleName"` MemberName string `json:"memberName"` MachineName string `json:"machineName"` RackName string `json:"rackName"` SiteName string `json:"siteName"` ProcessName string `json:"processName"` MemoryMaxMB int32 `json:"memoryMaxMB"` MemoryAvailableMB int32 `json:"memoryAvailableMB"` ReceiverSuccessRate float32 `json:"receiverSuccessRate"` PublisherSuccessRate float32 `json:"publisherSuccessRate"` TracingSamplingRatio float32 `json:"tracingSamplingRatio"` StorageEnabled bool `json:"storageEnabled"` PacketDeliveryEfficiency float64 `json:"packetDeliveryEfficiency"` PacketsResent int64 `json:"packetsResent"` PacketsSent int64 `json:"packetsSent"` PacketsReceived int64 `json:"packetsReceived"` SendQueueSize int64 `json:"sendQueueSize"` TransportReceivedBytes int64 `json:"transportReceivedBytes"` TransportSentBytes int64 `json:"transportSentBytes"` WeakestChannel int32 `json:"weakestChannel"` }
Member contains an individual members output.
type Members ¶
type Members struct {
Members []Member `json:"items"`
}
Members contains an array of member objects.
type NetworkStats ¶
type NetworkStats struct {
ViewerStatistics []string `json:"viewerStatistics"`
}
NetworkStats is used to decode network stats call for a member.
type NetworkStatsDetails ¶
type NetworkStatsDetails struct { NodeID string `json:"nodeId"` ReceiverSuccessRate float32 `json:"receiverSuccessRate"` PublisherSuccessRate float32 `json:"publisherSuccessRate"` PauseRate float32 `json:"pauseRate"` Threshold int64 `json:"threshold"` Paused bool `json:"paused"` Deferring bool `json:"deferring"` OutstandingPackets int64 `json:"outstandingPackets"` DeferredPackets int64 `json:"deferredPackets"` ReadyPackets int64 `json:"readyPackets"` LastIn string `json:"lastIn"` LastOut string `json:"lastOut"` LastSlow string `json:"LastSlow"` LastHeuristicDeath string `json:"lastHeuristicDeath"` }
NetworkStatsDetails contains viewer statistics for a member.
type Ownership ¶
type Ownership struct {
Details string `json:"ownership"`
}
Ownership contains partition ownership distributions.
type PartitionOwnership ¶
type PartitionOwnership struct { MemberID int TotalPartitions int PrimaryPartitions int BackupPartitions int // a map of partition ownership keyed by int where // 0 = primary, 1 = first backup, 2 = second backup.... // and value are the owned partitions PartitionMap map[int][]int // -o wide options Machine string Rack string Site string }
PartitionOwnership contains partition ownership for a service.
type PersistenceCoordinator ¶
type PersistenceCoordinator struct { Idle bool `json:"idle"` OperationStatus string `json:"operationStatus"` Snapshots []string `json:"snapshots"` CoordinatorNodeID int32 `json:"coordinatorId"` }
PersistenceCoordinator contains details about a persistence coordinator.
type ProxiesSummary ¶
type ProxiesSummary struct {
Proxies []ProxySummary `json:"items"`
}
ProxiesSummary contains a summary of individual proxy servers.
type ProxyConnection ¶
type ProxyConnection struct { NodeID string `json:"nodeId"` RemoteAddress string `json:"remoteAddress"` RemotePort int32 `json:"remotePort"` TimeStamp string `json:"timeStamp"` ConnectionTimeMillis int64 `json:"connectionTimeMillis"` ClientProcessName string `json:"clientProcessName"` TotalBytesReceived int64 `json:"totalBytesReceived"` TotalBytesSent int64 `json:"totalBytesSent"` OutgoingByteBacklog int64 `json:"outgoingByteBacklog"` UUID string `json:"UUID"` Member string `json:"member"` ClientRole string `json:"clientRole"` }
type ProxyConnections ¶
type ProxyConnections struct {
Proxies []ProxyConnection `json:"items"`
}
type ProxySummary ¶
type ProxySummary struct { HostIP string `json:"hostIP"` NodeID string `json:"nodeId"` ServiceName string `json:"name"` Type string `json:"type"` Protocol string `json:"protocol"` ConnectionCount int64 `json:"connectionCount"` // proxy service specific OutgoingMessageBacklog int64 `json:"outgoingMessageBacklog"` OutgoingByteBacklog int64 `json:"outgoingByteBacklog"` TotalBytesReceived int64 `json:"totalBytesReceived"` TotalBytesSent int64 `json:"totalBytesSent"` TotalMessagesReceived int64 `json:"totalMessagesReceived"` TotalMessagesSent int64 `json:"totalMessagesSent"` UnAuthConnectionAttempts int64 `json:"unauthorizedConnectionAttempts"` HTTPServerType string `json:"httpServerType"` // http service specific TotalRequestCount int64 `json:"totalRequestCount"` TotalErrorCount int64 `json:"totalErrorCount"` ResponseCount1xx int64 `json:"responseCount1xx"` ResponseCount2xx int64 `json:"responseCount2xx"` ResponseCount3xx int64 `json:"responseCount3xx"` ResponseCount4xx int64 `json:"responseCount4xx"` ResponseCount5xx int64 `json:"responseCount5xx"` }
ProxySummary contains proxy server summary details.
type Reporter ¶
type Reporter struct { NodeID string `json:"nodeId"` State string `json:"state"` OutputPath string `json:"outputPath"` ConfigFile string `json:"configFile"` LastReport string `json:"lastReport"` LastRunMillis int32 `json:"runLastMillis"` CurrentBatch int32 `json:"currentBatch"` IntervalSeconds int32 `json:"intervalSeconds"` RunAverageMillis float64 `json:"runAverageMillis"` AutoStart bool `json:"autoStart"` }
Reporter contains individual node reporter details.
type Reporters ¶
type Reporters struct {
Reporters []Reporter `json:"items"`
}
Reporters contains reporter details.
type ServiceCache ¶
ServiceCache contains an individual service cache mapping.
type ServiceCaches ¶
type ServiceCaches struct {
Details []ServiceCache `json:"items"`
}
ServiceCaches contains a list of service cache.
type ServiceMemberDetail ¶
type ServiceMemberDetail struct { NodeID string `json:"nodeId"` ThreadCount int32 `json:"threadCount"` ThreadCountMin int32 `json:"threadCountMin"` ThreadCountMax int32 `json:"threadCountMax"` ThreadIdleCount int32 `json:"threadIdleCount"` TaskCount int32 `json:"taskCount"` TaskBacklog int32 `json:"taskBacklog"` OwnedPartitionsPrimary int32 `json:"ownedPartitionsPrimary"` OwnedPartitionsBackup int32 `json:"ownedPartitionsBackup"` RequestAverageDuration float32 `json:"requestAverageDuration"` TaskAverageDuration float32 `json:"taskAverageDuration"` }
ServiceMemberDetail contains details about a service and node.
type ServiceMemberDetails ¶
type ServiceMemberDetails struct {
Services []ServiceMemberDetail `json:"items"`
}
ServiceMemberDetails contains service members details.
type ServiceStorageSummary ¶
type ServiceStorageSummary struct { ServiceName string `json:"service"` AveragePartitionSizeKB int64 `json:"averagePartitionSizeKB"` MaxPartitionSizeKB int64 `json:"maxPartitionSizeKB"` AverageStorageSizeKB int64 `json:"averageStorageSizeKB"` MaxStorageSizeKB int64 `json:"maxStorageSizeKB"` MaxLoadNodeID int32 `json:"maxLoadNodeId"` PartitionCount int32 `json:"partitionCount"` ServiceNodeCount int32 `json:"serviceNodeCount"` }
ServiceStorageSummary contains a storage summary for individual services.
type ServiceSummary ¶
type ServiceSummary struct { NodeID string `json:"nodeId"` ServiceName string `json:"name"` ServiceType string `json:"type"` MemberCount int32 `json:"memberCount"` StorageEnabledCount int32 `json:"storageEnabledCount"` StatusHA string `json:"statusHA"` PartitionsAll int32 `json:"partitionsAll"` PartitionsEndangered int32 `json:"partitionsEndangered"` PartitionsVulnerable int32 `json:"partitionsVulnerable"` PartitionsUnbalanced int32 `json:"partitionsUnbalanced"` RequestPendingCount int32 `json:"requestPendingCount"` StorageEnabled bool `json:"storageEnabled"` QuorumStatus string `json:"quorumStatus"` SeniorMemberID int32 `json:"seniorMemberId"` // persistence related PersistenceMode string `json:"persistenceMode"` PersistenceActiveSpaceUsed int64 `json:"persistenceActiveSpaceUsed"` PersistenceBackupSpaceUsed int64 `json:"persistenceBackupSpaceUsed"` PersistenceLatencyMax int64 `json:"persistenceLatencyMax"` PersistenceLatencyAverage float64 `json:"persistenceLatencyAverage"` PersistenceSnapshotSpaceAvailable int64 `json:"persistenceSnapshotSpaceAvailable"` // derived PersistenceLatencyAverageTotal float64 Snapshots []string OperationStatus string Idle bool }
ServiceSummary contains a summary of individual services.
type ServicesStorageSummaries ¶
type ServicesStorageSummaries struct {
Services []ServiceStorageSummary `json:"items"`
}
ServicesStorageSummaries contains an array of ServiceStorageSummary.
type ServicesSummaries ¶
type ServicesSummaries struct {
Services []ServiceSummary `json:"items"`
}
ServicesSummaries contains an array of ServiceSummary.
type SingleStatusValue ¶
type SingleStatusValue struct {
Status string `json:"status"`
}
SingleStatusValue contains a single JFR status result.
type Snapshots ¶
type Snapshots struct { ServiceName string `json:"serviceName"` Snapshots []string `json:"snapshots"` }
Snapshots contains snapshots for services.
type StatsSummary ¶
type StatsSummary struct { Count int64 `json:"count"` Average float64 `json:"average"` Min float64 `json:"min"` Max float64 `json:"max"` Sum float64 `json:"sum"` }
StatsSummary contains statistics summaries.
type StatusValues ¶
type StatusValues struct {
Status []string `json:"status"`
}
StatusValues contains JFR status result.
type StorageDetail ¶
type StorageDetail struct { NodeID string `json:"nodeId"` OwnedPartitionsPrimary int `json:"ownedPartitionsPrimary"` }
StorageDetail contains an individual storage details for a member.
type StorageDetails ¶
type StorageDetails struct {
Details []StorageDetail `json:"items"`
}
StorageDetails contains a summary of storage member details.
type SubscriberChannelStats ¶
type SubscriberChannelStats struct { Channel int64 `json:"channel"` Empty bool `json:"empty"` Owned bool `json:"owned"` Head string `json:"head"` LastCommit string `json:"lastCommit"` LastReceived string `json:"lastReceived"` }
SubscriberChannelStats contains statistics summaries for channel subscribers.
type SubscriberGroupChannelStats ¶
type SubscriberGroupChannelStats struct { Channel int64 `json:"channel"` Head string `json:"head"` LastCommittedPosition string `json:"lastCommittedPosition"` LastCommittedTimestamp string `json:"lastCommittedTimestamp"` LastPolledTimestamp string `json:"lastPolledTimestamp"` OwningSubscriberID int64 `json:"owningSubscriberId"` OwningSubscriberMemberID int64 `json:"owningSubscriberMemberId"` OwningSubscriberMemberNotificationID int64 `json:"owningSubscriberMemberNotificationId"` OwningSubscriberMemberUUID string `json:"owningSubscriberMemberUuid"` PolledCount int64 `json:"polledCount"` PolledMeanRate float64 `json:"polledMeanRate"` PolledOneMinuteRate float64 `json:"polledOneMinuteRate"` PolledFiveMinuteRate float64 `json:"polledFiveMinuteRate"` PolledFifteenMinuteRate float64 `json:"polledFifteenMinuteRate"` RemainingUnpolledMessages int64 `json:"remainingUnpolledMessages"` }
SubscriberGroupChannelStats contains statistics summaries for channel subscriber groups.
type TopicDetail ¶
type TopicDetail struct { ServiceName string `json:"service"` TopicName string `json:"name"` Members int64 `json:"members"` Channels int64 `json:"-"` Subscribers int64 `json:"-"` PublishedCount int64 `json:"-"` }
TopicDetail contains individual topic details.
type TopicDetails ¶
type TopicDetails struct {
Details []TopicDetail `json:"items"`
}
TopicDetails contains topics details.
type TopicsMemberDetail ¶
type TopicsMemberDetail struct { ServiceName string `json:"service"` TopicName string `json:"name"` NodeID string `json:"nodeId"` ChannelCount int64 `json:"channelCount"` ReconnectRetry int64 `json:"reconnectRetry"` RetainConsumed bool `json:"retainConsumed"` AllowUnownedCommits bool `json:"allowUnownedCommits"` SubscriberTimeout int64 `json:"subscriberTimeout"` ReconnectTimeout int64 `json:"reconnectTimeout"` ReconnectWait int64 `json:"reconnectWait"` PageCapacity int64 `json:"pageCapacity"` ElementCalculator string `json:"elementCalculator"` Member string `json:"member"` Cluster string `json:"cluster"` Channels map[string]interface{} `json:"channels"` PublishedCount int64 `json:"publishedCount"` PublishedMeanRate float64 `json:"publishedMeanRate"` PublishedOneMinuteRate float64 `json:"publishedOneMinuteRate"` PublishedFiveMinuteRate float64 `json:"publishedFiveMinuteRate"` PublishedFifteenMinuteRate float64 `json:"publishedFifteenMinuteRate"` }
TopicsMemberDetail contains individual detailed member information for a topic.
type TopicsMemberDetails ¶
type TopicsMemberDetails struct {
Details []TopicsMemberDetail `json:"items"`
}
TopicsMemberDetails contains topics member details.
type TopicsSubscriberDetail ¶
type TopicsSubscriberDetail struct { ServiceName string `json:"service"` TopicName string `json:"topic"` NodeID string `json:"nodeId"` ID int64 `json:"id"` ChannelCount int64 `json:"channelCount"` StateName string `json:"stateName"` SubscriberGroup string `json:"subscriberGroup"` ReceiveCompletions int64 `json:"receiveCompletions"` Waits int64 `json:"waits"` ReceiveErrors int64 `json:"receiveErrors"` ReceivedCount int64 `json:"receivedCount"` Disconnections int64 `json:"disconnections"` Notifications int64 `json:"notifications"` Backlog int64 `json:"backlog"` ReceiveBacklog int64 `json:"receiveBacklog"` Member string `json:"member"` Cluster string `json:"cluster"` Channels map[string]interface{} `json:"channels"` SubType string `json:"subType"` }
TopicsSubscriberDetail contains individual detailed subscriber information for a topic.
type TopicsSubscriberDetails ¶
type TopicsSubscriberDetails struct {
Details []TopicsSubscriberDetail `json:"items"`
}
TopicsSubscriberDetails contains topics subscriber details.
type TopicsSubscriberGroupDetail ¶
type TopicsSubscriberGroupDetail struct { ServiceName string `json:"service"` TopicName string `json:"topic"` NodeID string `json:"nodeId"` SubscriberGroup string `json:"name"` ChannelCount int64 `json:"channelCount"` PolledCount int64 `json:"polledCount"` PolledMeanRate float64 `json:"polledMeanRate"` PolledOneMinuteRate float64 `json:"polledOneMinuteRate"` PolledFiveMinuteRate float64 `json:"polledFiveMinuteRate"` PolledFifteenMinuteRate float64 `json:"polledFifteenMinuteRate"` Channels map[string]interface{} `json:"channels"` }
TopicsSubscriberGroupDetail contains detail about subscriber groups.
type TopicsSubscriberGroups ¶
type TopicsSubscriberGroups struct {
Details []TopicsSubscriberGroupDetail `json:"items"`
}
TopicsSubscriberGroups contains details about subscriber groups.
type ViewCacheDetail ¶
type ViewCacheDetail struct { ServiceName string `json:"service"` ViewName string `json:"viewName"` Name string `json:"name"` NodeID string `json:"nodeId"` Size int64 `json:"size"` ReconnectInterval int64 `json:"reconnectInterval"` Filter string `json:"filter"` Transformed bool `json:"transformed"` Transformer string `json:"transformer"` ReadOnly bool `json:"readOnly"` }
ViewCacheDetail contains a summary of view cache details.
type ViewCacheDetails ¶
type ViewCacheDetails struct {
ViewCaches []ViewCacheDetail `json:"items"`
}
ViewCacheDetails contains view cache details.
type ViewCacheSummaries ¶
type ViewCacheSummaries struct {
ViewCaches []ViewCacheSummaryDetail `json:"items"`
}
ViewCacheSummaries contains view cache summary details.
type ViewCacheSummaryDetail ¶
type ViewCacheSummaryDetail struct { ServiceName string `json:"service"` ViewName string `json:"name"` MemberCount int32 `json:"memberCount"` }
ViewCacheSummaryDetail contains a summary of cache details.