Documentation ¶
Index ¶
- Variables
- func GenerateBindingInfo(binding *topology.Binding) (*rabbithole.BindingInfo, error)
- func GenerateExchangeSettings(e *topology.Exchange) (*rabbithole.ExchangeSettings, error)
- func GenerateFederationDefinition(f *topology.Federation, uri string) rabbithole.FederationDefinition
- func GeneratePermissions(p *topology.Permission) rabbithole.Permissions
- func GeneratePolicy(p *topology.Policy) (*rabbithole.Policy, error)
- func GeneratePropertiesKey(binding *topology.Binding) string
- func GenerateQueueSettings(q *topology.Queue) (*rabbithole.QueueSettings, error)
- func GenerateShovelDefinition(s *topology.Shovel, srcUri, destUri string) rabbithole.ShovelDefinition
- func GenerateUserSettings(credentials *corev1.Secret, tags []topology.UserTag) (rabbithole.UserSettings, error)
- func GenerateVhostSettings(v *topology.Vhost) *rabbithole.VhostSettings
- func ParseRabbitmqClusterReference(ctx context.Context, c client.Client, rmq topology.RabbitmqClusterReference, ...) (*rabbitmqv1beta1.RabbitmqCluster, *corev1.Service, *corev1.Secret, error)
- func RandomEncodedString(dataLen int) (string, error)
- type RabbitMQClient
- type RabbitMQClientFactory
- type UpstreamEndpoints
Constants ¶
This section is empty.
Variables ¶
View Source
var NoSuchRabbitmqClusterError = errors.New("RabbitmqCluster object does not exist")
Functions ¶
func GenerateBindingInfo ¶
func GenerateBindingInfo(binding *topology.Binding) (*rabbithole.BindingInfo, error)
func GenerateExchangeSettings ¶
func GenerateExchangeSettings(e *topology.Exchange) (*rabbithole.ExchangeSettings, error)
func GenerateFederationDefinition ¶
func GenerateFederationDefinition(f *topology.Federation, uri string) rabbithole.FederationDefinition
func GeneratePermissions ¶
func GeneratePermissions(p *topology.Permission) rabbithole.Permissions
func GeneratePolicy ¶
func GeneratePolicy(p *topology.Policy) (*rabbithole.Policy, error)
func GeneratePropertiesKey ¶
func GenerateQueueSettings ¶
func GenerateQueueSettings(q *topology.Queue) (*rabbithole.QueueSettings, error)
generates rabbithole.QueueSettings for a given Queue queue.Spec.Arguments (type k8s runtime.RawExtensions) is unmarshalled Unmarshall stores float64, for JSON numbers See: https://golang.org/pkg/encoding/json/#Unmarshal
func GenerateShovelDefinition ¶
func GenerateShovelDefinition(s *topology.Shovel, srcUri, destUri string) rabbithole.ShovelDefinition
func GenerateUserSettings ¶
func GenerateUserSettings(credentials *corev1.Secret, tags []topology.UserTag) (rabbithole.UserSettings, error)
func GenerateVhostSettings ¶
func GenerateVhostSettings(v *topology.Vhost) *rabbithole.VhostSettings
func ParseRabbitmqClusterReference ¶ added in v0.7.0
func ParseRabbitmqClusterReference(ctx context.Context, c client.Client, rmq topology.RabbitmqClusterReference, namespace string) (*rabbitmqv1beta1.RabbitmqCluster, *corev1.Service, *corev1.Secret, error)
func RandomEncodedString ¶
Types ¶
type RabbitMQClient ¶ added in v0.5.1
type RabbitMQClient interface { PutUser(string, rabbithole.UserSettings) (*http.Response, error) DeleteUser(string) (*http.Response, error) DeclareBinding(string, rabbithole.BindingInfo) (*http.Response, error) DeleteBinding(string, rabbithole.BindingInfo) (*http.Response, error) ListQueueBindingsBetween(string, string, string) ([]rabbithole.BindingInfo, error) ListExchangeBindingsBetween(string, string, string) ([]rabbithole.BindingInfo, error) UpdatePermissionsIn(string, string, rabbithole.Permissions) (*http.Response, error) ClearPermissionsIn(string, string) (*http.Response, error) PutPolicy(string, string, rabbithole.Policy) (*http.Response, error) DeletePolicy(string, string) (*http.Response, error) DeclareQueue(string, string, rabbithole.QueueSettings) (*http.Response, error) DeleteQueue(string, string, ...rabbithole.QueueDeleteOptions) (*http.Response, error) DeclareExchange(string, string, rabbithole.ExchangeSettings) (*http.Response, error) DeleteExchange(string, string) (*http.Response, error) PutVhost(string, rabbithole.VhostSettings) (*http.Response, error) DeleteVhost(string) (*http.Response, error) PutGlobalParameter(name string, value interface{}) (*http.Response, error) DeleteGlobalParameter(name string) (*http.Response, error) PutFederationUpstream(vhost, name string, def rabbithole.FederationDefinition) (res *http.Response, err error) DeleteFederationUpstream(vhost, name string) (res *http.Response, err error) DeclareShovel(vhost, shovel string, info rabbithole.ShovelDefinition) (res *http.Response, err error) DeleteShovel(vhost, shovel string) (res *http.Response, err error) }
type RabbitMQClientFactory ¶ added in v0.5.1
type RabbitMQClientFactory func(rmq *rabbitmqv1beta1.RabbitmqCluster, svc *corev1.Service, secret *corev1.Secret, hostname string, certPool *x509.CertPool) (RabbitMQClient, error)
var RabbitholeClientFactory RabbitMQClientFactory = func(rmq *rabbitmqv1beta1.RabbitmqCluster, svc *corev1.Service, secret *corev1.Secret, hostname string, certPool *x509.CertPool) (RabbitMQClient, error) {
return generateRabbitholeClient(rmq, svc, secret, hostname, certPool)
}
type UpstreamEndpoints ¶
type UpstreamEndpoints struct { Username string `json:"username"` Password string `json:"password"` Endpoints []string `json:"endpoints"` }
func GenerateSchemaReplicationParameters ¶
func GenerateSchemaReplicationParameters(secret *corev1.Secret) (UpstreamEndpoints, error)
Source Files ¶
Click to show internal directories.
Click to hide internal directories.