Documentation
¶
Index ¶
- Constants
- func GetPubSub(pubSubType string) interface{}
- func Subscribe(pubSubType string, topic int, subscriber interface{}) error
- type AZ
- type CEN
- type DHCPPort
- type Domain
- type DomainPubSub
- type FloatingIP
- type Host
- type LANIP
- type LB
- type LBListener
- type LBTargetServer
- type LBVMConnection
- type Manager
- type NATGateway
- type NATRule
- type NATVMConnection
- type Network
- type PeerConnection
- type Pod
- type PodCluster
- type PodGroup
- type PodGroupPort
- type PodIngress
- type PodIngressRule
- type PodIngressRuleBackend
- type PodNamespace
- type PodNode
- type PodReplicaSet
- type PodService
- type PodServicePort
- type Process
- type PubSub
- type PubSubComponent
- type RDSInstance
- type RedisInstance
- type Region
- type ResourceBatchAddedSubscriber
- type ResourceBatchDeletedSubscriber
- type ResourceChangedSubscriber
- type ResourcePubSub
- type ResourcePubSubComponent
- func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchAdded(md *message.Metadata, msg MAPT)
- func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchDeleted(md *message.Metadata, msg MDPT)
- func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishChange(md *message.Metadata)
- func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishUpdated(md *message.Metadata, msg MUPT)
- type ResourceUpdatedSubscriber
- type RoutingTable
- type SubDomain
- type Subnet
- type VIP
- type VInterface
- type VM
- type VMPodNodeConnection
- type VPC
- type VRouter
- type WANIP
Constants ¶
View Source
const ( PubSubTypeAllDomains = "all_domains" PubSubTypeDomain = "domain" PubSubTypeRegion = common.RESOURCE_TYPE_REGION_EN PubSubTypeAZ = common.RESOURCE_TYPE_AZ_EN PubSubTypeSubDomain = common.RESOURCE_TYPE_SUB_DOMAIN_EN PubSubTypeHost = common.RESOURCE_TYPE_HOST_EN PubSubTypeVM = common.RESOURCE_TYPE_VM_EN PubSubTypeVMPodNodeConnection = common.RESOURCE_TYPE_VM_POD_NODE_CONNECTION_EN PubSubTypeVPC = common.RESOURCE_TYPE_VPC_EN PubSubTypeNetwork = common.RESOURCE_TYPE_NETWORK_EN PubSubTypeSubnet = common.RESOURCE_TYPE_SUBNET_EN PubSubTypeVRouter = common.RESOURCE_TYPE_VROUTER_EN PubSubTypeRoutingTable = common.RESOURCE_TYPE_ROUTING_TABLE_EN PubSubTypeDHCPPort = common.RESOURCE_TYPE_DHCP_PORT_EN PubSubTypeVInterface = common.RESOURCE_TYPE_VINTERFACE_EN PubSubTypeFloatingIP = common.RESOURCE_TYPE_FLOATING_IP_EN PubSubTypeWANIP = common.RESOURCE_TYPE_WAN_IP_EN PubSubTypeLANIP = common.RESOURCE_TYPE_LAN_IP_EN PubSubTypeVIP = common.RESOURCE_TYPE_VIP_EN PubSubTypeNATGateway = common.RESOURCE_TYPE_NAT_GATEWAY_EN PubSubTypeNATRule = common.RESOURCE_TYPE_NAT_RULE_EN PubSubTypeNATVMConnection = common.RESOURCE_TYPE_NAT_VM_CONNECTION_EN PubSubTypeLB = common.RESOURCE_TYPE_LB_EN PubSubTypeLBListener = common.RESOURCE_TYPE_LB_LISTENER_EN PubSubTypeLBTargetServer = common.RESOURCE_TYPE_LB_TARGET_SERVER_EN PubSubTypeLBVMConnection = common.RESOURCE_TYPE_LB_VM_CONNECTION_EN PubSubTypePeerConnection = common.RESOURCE_TYPE_PEER_CONNECTION_EN PubSubTypeCEN = common.RESOURCE_TYPE_CEN_EN PubSubTypeRDSInstance = common.RESOURCE_TYPE_RDS_INSTANCE_EN PubSubTypeRedisInstance = common.RESOURCE_TYPE_REDIS_INSTANCE_EN PubSubTypePodCluster = common.RESOURCE_TYPE_POD_CLUSTER_EN PubSubTypePodNode = common.RESOURCE_TYPE_POD_NODE_EN PubSubTypePodNamespace = common.RESOURCE_TYPE_POD_NAMESPACE_EN PubSubTypePodIngress = common.RESOURCE_TYPE_POD_INGRESS_EN PubSubTypePodIngressRule = common.RESOURCE_TYPE_POD_INGRESS_RULE_EN PubSubTypePodIngressRuleBackend = common.RESOURCE_TYPE_POD_INGRESS_RULE_BACKEND_EN PubSubTypePodService = common.RESOURCE_TYPE_POD_SERVICE_EN PubSubTypePodServicePort = common.RESOURCE_TYPE_POD_SERVICE_PORT_EN PubSubTypePodGroup = common.RESOURCE_TYPE_POD_GROUP_EN PubSubTypePodGroupPort = common.RESOURCE_TYPE_POD_GROUP_PORT_EN PubSubTypePodReplicaSet = common.RESOURCE_TYPE_POD_REPLICA_SET_EN PubSubTypePod = common.RESOURCE_TYPE_POD_EN PubSubTypeProcess = common.RESOURCE_TYPE_PROCESS_EN )
View Source
const ( TopicResourceChanged = iota // subscribe to this topic to get notification of resource changed TopicResourceBatchAddedMySQL // subscribe to this topic to get MySQL model data of resource batch added TopicResourceUpdatedFields // subscribe to this topic to get message update model data of resource updated TopicResourceUpdatedMessageUpdate // subscribe to this topic to get message update model data of resource updated TopicResourceBatchDeletedLcuuid // subscribe to this topic to get lcuuids of resource batch deleted TopicResourceBatchDeletedMySQL // subscribe to this topic to get MySQL model data of resource batch deleted )
Variables ¶
This section is empty.
Functions ¶
Types ¶
type AZ ¶
type CEN ¶
type DHCPPort ¶
type DHCPPort struct {
ResourcePubSubComponent[
*message.DHCPPortAdd,
message.DHCPPortAdd,
*message.DHCPPortUpdate,
message.DHCPPortUpdate,
*message.DHCPPortFieldsUpdate,
message.DHCPPortFieldsUpdate,
*message.DHCPPortDelete,
message.DHCPPortDelete]
}
func NewDHCPPort ¶
func NewDHCPPort() *DHCPPort
type DomainPubSub ¶
type DomainPubSub interface {
PubSub
PublishChange(*message.Metadata) // publish any change of the cloud platform, only notify the fact that the cloud platform has been changed, without specific changed data.
}
PubSub interface for the whole cloud platform
type FloatingIP ¶
type FloatingIP struct {
ResourcePubSubComponent[
*message.FloatingIPAdd,
message.FloatingIPAdd,
*message.FloatingIPUpdate,
message.FloatingIPUpdate,
*message.FloatingIPFieldsUpdate,
message.FloatingIPFieldsUpdate,
*message.FloatingIPDelete,
message.FloatingIPDelete]
}
func NewFloatingIP ¶
func NewFloatingIP() *FloatingIP
type Host ¶
type Host struct {
ResourcePubSubComponent[
*message.HostAdd,
message.HostAdd,
*message.HostUpdate,
message.HostUpdate,
*message.HostFieldsUpdate,
message.HostFieldsUpdate,
*message.HostDelete,
message.HostDelete]
}
type LANIP ¶
type LANIP struct {
ResourcePubSubComponent[
*message.LANIPAdd,
message.LANIPAdd,
*message.LANIPUpdate,
message.LANIPUpdate,
*message.LANIPFieldsUpdate,
message.LANIPFieldsUpdate,
*message.LANIPDelete,
message.LANIPDelete]
}
type LB ¶
type LBListener ¶
type LBListener struct {
ResourcePubSubComponent[
*message.LBListenerAdd,
message.LBListenerAdd,
*message.LBListenerUpdate,
message.LBListenerUpdate,
*message.LBListenerFieldsUpdate,
message.LBListenerFieldsUpdate,
*message.LBListenerDelete,
message.LBListenerDelete]
}
func NewLBListener ¶
func NewLBListener() *LBListener
type LBTargetServer ¶
type LBTargetServer struct {
ResourcePubSubComponent[
*message.LBTargetServerAdd,
message.LBTargetServerAdd,
*message.LBTargetServerUpdate,
message.LBTargetServerUpdate,
*message.LBTargetServerFieldsUpdate,
message.LBTargetServerFieldsUpdate,
*message.LBTargetServerDelete,
message.LBTargetServerDelete]
}
func NewLBTargetServer ¶
func NewLBTargetServer() *LBTargetServer
type LBVMConnection ¶
type LBVMConnection struct {
ResourcePubSubComponent[
*message.LBVMConnectionAdd,
message.LBVMConnectionAdd,
*message.LBVMConnectionUpdate,
message.LBVMConnectionUpdate,
*message.LBVMConnectionFieldsUpdate,
message.LBVMConnectionFieldsUpdate,
*message.LBVMConnectionDelete,
message.LBVMConnectionDelete]
}
func NewLBVMConnection ¶
func NewLBVMConnection() *LBVMConnection
type Manager ¶
func GetManager ¶
func GetManager() *Manager
type NATGateway ¶
type NATGateway struct {
ResourcePubSubComponent[
*message.NATGatewayAdd,
message.NATGatewayAdd,
*message.NATGatewayUpdate,
message.NATGatewayUpdate,
*message.NATGatewayFieldsUpdate,
message.NATGatewayFieldsUpdate,
*message.NATGatewayDelete,
message.NATGatewayDelete]
}
func NewNATGateway ¶
func NewNATGateway() *NATGateway
type NATRule ¶
type NATRule struct {
ResourcePubSubComponent[
*message.NATRuleAdd,
message.NATRuleAdd,
*message.NATRuleUpdate,
message.NATRuleUpdate,
*message.NATRuleFieldsUpdate,
message.NATRuleFieldsUpdate,
*message.NATRuleDelete,
message.NATRuleDelete]
}
func NewNATRule ¶
func NewNATRule() *NATRule
type NATVMConnection ¶
type NATVMConnection struct {
ResourcePubSubComponent[
*message.NATVMConnectionAdd,
message.NATVMConnectionAdd,
*message.NATVMConnectionUpdate,
message.NATVMConnectionUpdate,
*message.NATVMConnectionFieldsUpdate,
message.NATVMConnectionFieldsUpdate,
*message.NATVMConnectionDelete,
message.NATVMConnectionDelete]
}
func NewNATVMConnection ¶
func NewNATVMConnection() *NATVMConnection
type Network ¶
type Network struct {
ResourcePubSubComponent[
*message.NetworkAdd,
message.NetworkAdd,
*message.NetworkUpdate,
message.NetworkUpdate,
*message.NetworkFieldsUpdate,
message.NetworkFieldsUpdate,
*message.NetworkDelete,
message.NetworkDelete]
}
func NewNetwork ¶
func NewNetwork() *Network
type PeerConnection ¶
type PeerConnection struct {
ResourcePubSubComponent[
*message.PeerConnectionAdd,
message.PeerConnectionAdd,
*message.PeerConnectionUpdate,
message.PeerConnectionUpdate,
*message.PeerConnectionFieldsUpdate,
message.PeerConnectionFieldsUpdate,
*message.PeerConnectionDelete,
message.PeerConnectionDelete]
}
func NewPeerConnection ¶
func NewPeerConnection() *PeerConnection
type Pod ¶
type PodCluster ¶
type PodCluster struct {
ResourcePubSubComponent[
*message.PodClusterAdd,
message.PodClusterAdd,
*message.PodClusterUpdate,
message.PodClusterUpdate,
*message.PodClusterFieldsUpdate,
message.PodClusterFieldsUpdate,
*message.PodClusterDelete,
message.PodClusterDelete]
}
func NewPodCluster ¶
func NewPodCluster() *PodCluster
type PodGroup ¶
type PodGroup struct {
ResourcePubSubComponent[
*message.PodGroupAdd,
message.PodGroupAdd,
*message.PodGroupUpdate,
message.PodGroupUpdate,
*message.PodGroupFieldsUpdate,
message.PodGroupFieldsUpdate,
*message.PodGroupDelete,
message.PodGroupDelete]
}
func NewPodGroup ¶
func NewPodGroup() *PodGroup
type PodGroupPort ¶
type PodGroupPort struct {
ResourcePubSubComponent[
*message.PodGroupPortAdd,
message.PodGroupPortAdd,
*message.PodGroupPortUpdate,
message.PodGroupPortUpdate,
*message.PodGroupPortFieldsUpdate,
message.PodGroupPortFieldsUpdate,
*message.PodGroupPortDelete,
message.PodGroupPortDelete]
}
func NewPodGroupPort ¶
func NewPodGroupPort() *PodGroupPort
type PodIngress ¶
type PodIngress struct {
ResourcePubSubComponent[
*message.PodIngressAdd,
message.PodIngressAdd,
*message.PodIngressUpdate,
message.PodIngressUpdate,
*message.PodIngressFieldsUpdate,
message.PodIngressFieldsUpdate,
*message.PodIngressDelete,
message.PodIngressDelete]
}
func NewPodIngress ¶
func NewPodIngress() *PodIngress
type PodIngressRule ¶
type PodIngressRule struct {
ResourcePubSubComponent[
*message.PodIngressRuleAdd,
message.PodIngressRuleAdd,
*message.PodIngressRuleUpdate,
message.PodIngressRuleUpdate,
*message.PodIngressRuleFieldsUpdate,
message.PodIngressRuleFieldsUpdate,
*message.PodIngressRuleDelete,
message.PodIngressRuleDelete]
}
func NewPodIngressRule ¶
func NewPodIngressRule() *PodIngressRule
type PodIngressRuleBackend ¶
type PodIngressRuleBackend struct {
ResourcePubSubComponent[
*message.PodIngressRuleBackendAdd,
message.PodIngressRuleBackendAdd,
*message.PodIngressRuleBackendUpdate,
message.PodIngressRuleBackendUpdate,
*message.PodIngressRuleBackendFieldsUpdate,
message.PodIngressRuleBackendFieldsUpdate,
*message.PodIngressRuleBackendDelete,
message.PodIngressRuleBackendDelete]
}
func NewPodIngressRuleBackend ¶
func NewPodIngressRuleBackend() *PodIngressRuleBackend
type PodNamespace ¶
type PodNamespace struct {
ResourcePubSubComponent[
*message.PodNamespaceAdd,
message.PodNamespaceAdd,
*message.PodNamespaceUpdate,
message.PodNamespaceUpdate,
*message.PodNamespaceFieldsUpdate,
message.PodNamespaceFieldsUpdate,
*message.PodNamespaceDelete,
message.PodNamespaceDelete]
}
func NewPodNamespace ¶
func NewPodNamespace() *PodNamespace
type PodNode ¶
type PodNode struct {
ResourcePubSubComponent[
*message.PodNodeAdd,
message.PodNodeAdd,
*message.PodNodeUpdate,
message.PodNodeUpdate,
*message.PodNodeFieldsUpdate,
message.PodNodeFieldsUpdate,
*message.PodNodeDelete,
message.PodNodeDelete]
}
func NewPodNode ¶
func NewPodNode() *PodNode
type PodReplicaSet ¶
type PodReplicaSet struct {
ResourcePubSubComponent[
*message.PodReplicaSetAdd,
message.PodReplicaSetAdd,
*message.PodReplicaSetUpdate,
message.PodReplicaSetUpdate,
*message.PodReplicaSetFieldsUpdate,
message.PodReplicaSetFieldsUpdate,
*message.PodReplicaSetDelete,
message.PodReplicaSetDelete]
}
func NewPodReplicaSet ¶
func NewPodReplicaSet() *PodReplicaSet
type PodService ¶
type PodService struct {
ResourcePubSubComponent[
*message.PodServiceAdd,
message.PodServiceAdd,
*message.PodServiceUpdate,
message.PodServiceUpdate,
*message.PodServiceFieldsUpdate,
message.PodServiceFieldsUpdate,
*message.PodServiceDelete,
message.PodServiceDelete]
}
func NewPodService ¶
func NewPodService() *PodService
type PodServicePort ¶
type PodServicePort struct {
ResourcePubSubComponent[
*message.PodServicePortAdd,
message.PodServicePortAdd,
*message.PodServicePortUpdate,
message.PodServicePortUpdate,
*message.PodServicePortFieldsUpdate,
message.PodServicePortFieldsUpdate,
*message.PodServicePortDelete,
message.PodServicePortDelete]
}
func NewPodServicePort ¶
func NewPodServicePort() *PodServicePort
type Process ¶
type Process struct {
ResourcePubSubComponent[
*message.ProcessAdd,
message.ProcessAdd,
*message.ProcessUpdate,
message.ProcessUpdate,
*message.ProcessFieldsUpdate,
message.ProcessFieldsUpdate,
*message.ProcessDelete,
message.ProcessDelete]
}
func NewProcess ¶
func NewProcess() *Process
type PubSubComponent ¶
type PubSubComponent struct {
// contains filtered or unexported fields
}
func (*PubSubComponent) Subscribe ¶
func (p *PubSubComponent) Subscribe(topic int, subscriber interface{})
func (*PubSubComponent) Unsubscribe ¶
func (p *PubSubComponent) Unsubscribe(topic int, subscriber interface{})
type RDSInstance ¶
type RDSInstance struct {
ResourcePubSubComponent[
*message.RDSInstanceAdd,
message.RDSInstanceAdd,
*message.RDSInstanceUpdate,
message.RDSInstanceUpdate,
*message.RDSInstanceFieldsUpdate,
message.RDSInstanceFieldsUpdate,
*message.RDSInstanceDelete,
message.RDSInstanceDelete]
}
func NewRDSInstance ¶
func NewRDSInstance() *RDSInstance
type RedisInstance ¶
type RedisInstance struct {
ResourcePubSubComponent[
*message.RedisInstanceAdd,
message.RedisInstanceAdd,
*message.RedisInstanceUpdate,
message.RedisInstanceUpdate,
*message.RedisInstanceFieldsUpdate,
message.RedisInstanceFieldsUpdate,
*message.RedisInstanceDelete,
message.RedisInstanceDelete]
}
func NewRedisInstance ¶
func NewRedisInstance() *RedisInstance
type Region ¶
type Region struct {
ResourcePubSubComponent[
*message.RegionAdd,
message.RegionAdd,
*message.RegionUpdate,
message.RegionUpdate,
*message.RegionFieldsUpdate,
message.RegionFieldsUpdate,
*message.RegionDelete,
message.RegionDelete]
}
type ResourcePubSub ¶
type ResourcePubSub[ MAPT constraint.AddPtr[MAT], MAT constraint.Add, MUPT constraint.UpdatePtr[MUT], MUT constraint.Update, MFUPT constraint.FieldsUpdatePtr[MFUT], MFUT constraint.FieldsUpdate, MDPT constraint.DeletePtr[MDT], MDT constraint.Delete, ] interface { PubSub PublishChange(*message.Metadata) // publish any change of the resource, only notify the fact that some of the whole resource has been changed, without specific changed data PublishBatchAdded(*message.Metadata, MAPT) // publish resource batch added notification, including specific data PublishUpdated(*message.Metadata, MUPT) // publish resource updated notification, including specific data PublishBatchDeleted(*message.Metadata, MDPT) // publish resource batch deleted notification, including specific data }
Pubsub interface for a specific resource
type ResourcePubSubComponent ¶
type ResourcePubSubComponent[ MAPT constraint.AddPtr[MAT], MAT constraint.Add, MUPT constraint.UpdatePtr[MUT], MUT constraint.Update, MFUPT constraint.FieldsUpdatePtr[MFUT], MFUT constraint.FieldsUpdate, MDPT constraint.DeletePtr[MDT], MDT constraint.Delete, ] struct { PubSubComponent // contains filtered or unexported fields }
func (*ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchAdded ¶
func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchAdded(md *message.Metadata, msg MAPT)
func (*ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchDeleted ¶
func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishBatchDeleted(md *message.Metadata, msg MDPT)
func (*ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishChange ¶
func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishChange(md *message.Metadata)
func (*ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishUpdated ¶
func (p *ResourcePubSubComponent[MAPT, MAT, MUPT, MUT, MFUPT, MFUT, MDPT, MDT]) PublishUpdated(md *message.Metadata, msg MUPT)
type RoutingTable ¶
type RoutingTable struct {
ResourcePubSubComponent[
*message.RoutingTableAdd,
message.RoutingTableAdd,
*message.RoutingTableUpdate,
message.RoutingTableUpdate,
*message.RoutingTableFieldsUpdate,
message.RoutingTableFieldsUpdate,
*message.RoutingTableDelete,
message.RoutingTableDelete]
}
func NewRoutingTable ¶
func NewRoutingTable() *RoutingTable
type SubDomain ¶
type SubDomain struct {
ResourcePubSubComponent[
*message.SubDomainAdd,
message.SubDomainAdd,
*message.SubDomainUpdate,
message.SubDomainUpdate,
*message.SubDomainFieldsUpdate,
message.SubDomainFieldsUpdate,
*message.SubDomainDelete,
message.SubDomainDelete]
}
func NewSubDomain ¶
func NewSubDomain() *SubDomain
type Subnet ¶
type Subnet struct {
ResourcePubSubComponent[
*message.SubnetAdd,
message.SubnetAdd,
*message.SubnetUpdate,
message.SubnetUpdate,
*message.SubnetFieldsUpdate,
message.SubnetFieldsUpdate,
*message.SubnetDelete,
message.SubnetDelete]
}
type VIP ¶
type VInterface ¶
type VInterface struct {
ResourcePubSubComponent[
*message.VInterfaceAdd,
message.VInterfaceAdd,
*message.VInterfaceUpdate,
message.VInterfaceUpdate,
*message.VInterfaceFieldsUpdate,
message.VInterfaceFieldsUpdate,
*message.VInterfaceDelete,
message.VInterfaceDelete]
}
func NewVInterface ¶
func NewVInterface() *VInterface
type VM ¶
type VMPodNodeConnection ¶
type VMPodNodeConnection struct {
ResourcePubSubComponent[
*message.VMPodNodeConnectionAdd,
message.VMPodNodeConnectionAdd,
*message.VMPodNodeConnectionUpdate,
message.VMPodNodeConnectionUpdate,
*message.VMPodNodeConnectionFieldsUpdate,
message.VMPodNodeConnectionFieldsUpdate,
*message.VMPodNodeConnectionDelete,
message.VMPodNodeConnectionDelete]
}
func NewVMPodNodeConnection ¶
func NewVMPodNodeConnection() *VMPodNodeConnection
type VPC ¶
type VRouter ¶
type VRouter struct {
ResourcePubSubComponent[
*message.VRouterAdd,
message.VRouterAdd,
*message.VRouterUpdate,
message.VRouterUpdate,
*message.VRouterFieldsUpdate,
message.VRouterFieldsUpdate,
*message.VRouterDelete,
message.VRouterDelete]
}
func NewVRouter ¶
func NewVRouter() *VRouter
type WANIP ¶
type WANIP struct {
ResourcePubSubComponent[
*message.WANIPAdd,
message.WANIPAdd,
*message.WANIPUpdate,
message.WANIPUpdate,
*message.WANIPFieldsUpdate,
message.WANIPFieldsUpdate,
*message.WANIPDelete,
message.WANIPDelete]
}
Source Files
¶
- az.go
- cen.go
- const.go
- dhcp_port.go
- domain.go
- floating_ip.go
- host.go
- lan_ip.go
- lb.go
- lb_listener.go
- lb_target_server.go
- lb_vm_connection.go
- manager.go
- nat_gateway.go
- nat_rule.go
- nat_vm_connection.go
- network.go
- peer_connection.go
- pod.go
- pod_cluster.go
- pod_group.go
- pod_group_port.go
- pod_ingress.go
- pod_ingress_rule.go
- pod_ingress_rule_backend.go
- pod_namespace.go
- pod_node.go
- pod_replica_set.go
- pod_service.go
- pod_service_port.go
- process.go
- pubsub.go
- rds_instance.go
- redis_instance.go
- region.go
- routing_table.go
- sub_domain.go
- subnet.go
- subscriber.go
- vinterface.go
- vip.go
- vm.go
- vm_pod_node_connection.go
- vpc.go
- vrouter.go
- wan_ip.go
Click to show internal directories.
Click to hide internal directories.