Skip to content

Releases: rabbitmq/cluster-operator

1.4.0

11 Jan 17:48
5191f32
Compare
Choose a tag to compare

Release Notes

  • Place RabbitMQ configuration in confd (#548) [5191f32]
  • Merge pull request #554 from rabbitmq/logger [bba233e]
  • Remove hard coded logger dev mode [66d4415]
  • Use logger from context in Reconcile() (#550) [9b239ea]
  • Add SAN docs (#552) [c92a7dc]
  • Fix merging of pod annotations (#547) [cf3bb45]
  • Use SatisfyAll for multiple assertions on the same object [cb25f3b]
  • Fix typos [025afe0]
  • Remove redundant type conversion [b4a0752]
  • Always set PVC override namespace to sts namespace [12a09a8]
  • Add prometheus tls example (#539) [a057a26]
  • Merge pull request #542 from rabbitmq/controller-runtime-0.7 [6d2c66a]
  • Create GH Actions workflow for CodeQL SAST (#544) [cffa917]
  • Manager.Start() now takes context instead of a channel [b2fd594]
  • Add context.Context to method Reconcile() [008f9c7]
  • Use client.Object instead of runtime.Object when necessary [15d36f2]
  • Update leader election role to leases.coordination.k8s.io [2f1c9fd]
  • Bump controller-runtime 0.7; k8s dependencies to 0.19 [75e85ab]
  • Prometheus fix standard port in TLS deploy (#541) [39e1851]
  • Merge pull request #536 from rabbitmq/dependabot/go_modules/sigs.k8s.io/kustomize/kustomize/v3-3.9.1 [5bc48e8]
  • Change prod example to use pause_minority strategy (#540) [a7d9c2b]
  • Merge pull request #535 from rabbitmq/dependabot/go_modules/github.com/eclipse/paho.mqtt.golang-1.3.1 [b83d596]
  • Merge pull request #526 from rabbitmq/dependabot/go_modules/github.com/go-stomp/stomp-2.1.0incompatible [905dc8f]
  • Bump sigs.k8s.io/kustomize/kustomize/v3 from 3.8.8 to 3.9.1 [0feba67]
  • Bump github.com/eclipse/paho.mqtt.golang from 1.3.0 to 1.3.1 [1342b8f]
  • Merge pull request #533 from rabbitmq/cluster-operator_479 [f5d195b]
  • Add space [97ce18d]
  • Add tests for prometheus TLS [eebd2ab]
  • Change prometheus annotation [d153a50]
  • Add support for prometheus TLS [7803fe7]
  • Bump github.com/go-stomp/stomp [58c6114]
  • Add kustomize to go tools (#531) [1e16079]

Notes

Upgrading the cluster-operator to this version will update RabbitMQ clusters (i.e. will cause rolling update of the underlying StatefulSets). If you want to control when a RabbitMQ cluster gets updated, make sure to pause reconciliation before upgrading the cluster-operator. After upgrading the cluster-operator, resume reconciliation whenever it's safe to update the RabbitMQ cluster. See Pause reconciliation for a RabbitMQ cluster.

1.3.0

16 Dec 17:19
a637934
Compare
Choose a tag to compare

Release Notes

  • Merge pull request #524 from rabbitmq/tls-rotation [a637934]
  • Use Expect/EventuallyWithOffset in system_tests/utils [f481878]
  • Mount tls secrets using projected volume not subpath [8427c41]
  • Merge pull request #523 from rabbitmq/pause-reconcile [d8a14c8]
  • Add pause & resume reconciliation commands to cli plugin [b97a788]
  • Spport pausing reconciliation by setting label on the CR [a27503b]
  • Merge pull request #516 from rabbitmq/dependabot/go_modules/github.com/eclipse/paho.mqtt.golang-1.3.0 [d84f9e0]
  • Merge pull request #521 from rabbitmq/pr-1.19 [ce22254]
  • Bump github.com/eclipse/paho.mqtt.golang from 1.2.0 to 1.3.0 [7aa94c2]
  • Merge pull request #519 from rabbitmq/dependabot/go_modules/github.com/onsi/gomega-1.10.4 [0f497bf]
  • Merge pull request #522 from rabbitmq/dependabot/go_modules/github.com/go-delve/delve-1.5.1 [d761a0c]
  • Bump github.com/go-delve/delve from 1.5.0 to 1.5.1 [69d51c0]
  • Include k8s 1.20.0 in PR tests [8f75db6]
  • Bump github.com/onsi/gomega from 1.10.3 to 1.10.4 [5f973a1]
  • Merge pull request #513 from rabbitmq/prometheus-example [9b90fc9]
  • Fix sporadic examples failures [30a323f]
  • Fix failing examples [7e14406]
  • Fix failing example dry run due to missing CRD [9b6d495]
  • Add monitoring example [8e7038f]

Notes

Upgrading the cluster-operator to this version will update RabbitMQ clusters (i.e. will cause rolling updates of the underlying StatefulSets). If you want to control when a RabbitMQ cluster gets updated, make sure to pause reconciliation before upgrading the cluster-operator. After upgrading the cluster-operator, resume reconciliation whenever it's safe to update the RabbitMQ cluster. See Pause reconciliation for a RabbitMQ cluster.

1.2.0

03 Dec 13:40
8f066d1
Compare
Choose a tag to compare

Release Notes

  • Merge pull request #501 from wbagdon/patch-1 [8f066d1]
  • Do not drop all capabilities [72ac2ff]
  • Always mount '/var/lib/rabbitmq/' before '/var/lib/rabbitmq/mnesia/' to avoid shadowing [b0a099b]
  • Fix topologySpreadConstraints labelSelector [78c88d5]
  • Fix permissions on mnesia [d1d7e9b]
  • Add PodDisruptionBudget (#510) [be8f992]
  • Fix spelling [6a15d4b]
  • Only run the templating test by default [dd2dbef]
  • Check whether the correct yq is available [1fc3237]
  • Add missing chart properties (#500) [9cb3aac]
  • Bump github.com/michaelklishin/rabbit-hole/v2 from 2.5.0 to 2.6.0 [dce6f5a]
  • Test all examples in PR github action [f2fac29]
  • Update README.md [c50f379]
  • Lower staleness threshold to 60 days (#499) [0432b5a]
  • Collect cloud provider info in bug report template [85735fa]
  • Merge pull request #478 from rabbitmq/reuse-cluster-generator-in-tests [594dbc2]
  • Reuse cluster generator in configmap tests [f59008e]

1.1.0

24 Nov 13:03
Compare
Choose a tag to compare

Release Notes

  • Merge error and requeueAfter branches [9f18c0f]
  • Requeue when conflict on status update [817ef95]
  • Stop disabling management tcp listener when tls enabled (#487) [57e7c6f]
  • Update service name in the binding (#486) [b2061cc]
  • Merge pull request #477 from rabbitmq/closenontlsport [e4c3759]
  • Add spec.tls.disableNonTLSListeners property [d1db350]
  • Bump sigs.k8s.io/controller-runtime from 0.6.3 to 0.6.4 (#484) [7ab7da0]
  • Increase upper CPU limit for system tests [b18f20f]
  • Make rabbitmq image configurable (#481) [870c6af]
  • Rename port http to management in service [d2e2383]
  • Example: mTLS between RabbitMQ nodes (#469) [7824d1e]
  • Merge pull request #476 from rabbitmq/controller-gen [4b2e9d9]
  • Remove crd patch hack [336d802]
  • Delete pod in persistence test (#475) [91c0d40]
  • Run make manifests (#473) [06a015f]
  • Bump sigs.k8s.io/controller-tools from 0.4.0 to 0.4.1 (#471) [60f24b8]

1.0.0

13 Nov 14:43
Compare
Choose a tag to compare

Breaking Changes

We have deleted the property spec.tls.caCertName. The cluster operator hardcodes the caCertName to ca.crt.

Release Notes

  • Correct mTLS example [934d6f7]
  • Share TLS config with management, amqp 1.0, (web) mqtt and (web) stomp plugins (#451) [41bbbbf]
  • Prepend git tag with v (#465) [f6f9bc8]
  • Merge pull request #461 from rabbitmq/update-kubernetes-version [6d3c093]
  • Add kubectl rabbitmq tail subcommand (#462) [8488f9f]
  • Fix failing release GitHub action (#460) [911ef0e]
  • Update minimum Kubernetes version [99c37e1]

0.49.0

10 Nov 15:37
ba7d532
Compare
Choose a tag to compare

Breaking Changes

We've renamed resources created by the operator to make them shorter. It makes it more convenient to work with RabbitMQ, especially (old names wouldn't even fit in some dashboards for example). Unfortunately that means that you have to delete your clusters before upgrading to 0.49, sorry. We wanted to make that change before releasing a stable version.

Release Notes

  • Merge pull request #449 from rabbitmq/label-annotation-inheritance [ba7d532]
  • Stop updating labels/annotations for plugins configMap [06a5c83]
  • Add 'kubectl rabbitmq version' command (#450) [a456659]
  • Stop updating label/annotation on server conf configMap [b127e59]
  • Stop populate CR labels/annotions to pods [660aa43]
  • Add automation to bump kubectl rabbitmq in krew index (#448) [4a06999]
  • Add tests for kubectl plugin (#445) [db113e5]
  • Merge pull request #447 from rabbitmq/rename [dda2be1]
  • Drop '-client' suffix from rmq service [b5d7713]
  • Rename headless svc suffix to "nodes" [bc8bc2f]
  • Remove 'rabbitmq' from child resources suffix [def80cc]
  • Move example file to the right folder [d76175b]
  • Merge pull request #401 from rabbitmq/production-example [3c93b46]
  • Add SSD storageClass example [6058344]
  • Merge pull request #443 from rabbitmq/cluster-operator-441 [7620e52]
  • Rename port 15672 to "management" (#444) [459c281]
  • Update RabbitMQ helm chart to also use the management variant [6f0af78]
  • Avoid unnecessary object updates (#438) [d4b6129]
  • Use management variant of RabbitMQ image as default [34f6600]
  • bump resources [2bb6bd7]
  • Enable all feature flags for new clusters (#434) [bab4c6e]
  • Ensure MY_POD_NAME, MY_POD_NAMESPACE, and K8S_SERVICE_NAME envVar defined first (#437) [d0298dc]
  • Merge pull request #436 from rabbitmq/fix-name-prefix-in-overlays [2a553b2]
  • Remove name prefix from default kustomization [d2c94a7]
  • Make TerminationGracePeriodSeconds configurable (#430) [7244faa]
  • Format expected config file with ini pkg (#429) [ada0c87]
  • Bump timeout in mqtt/stomp system tests (#428) [5d74b52]
  • Set up rabbitmqadmin automatically (#426) [3cba654]
  • Apply same code format for all resources (#427) [6fc47e6]
  • Separate rabbitmqcluster_controller into smaller files (#418) [7fdb23c]
  • Use the well-known topologyKey [30c6627]
  • An example of a production cluster configuration. [c8be0b3]

0.48.0

28 Oct 10:36
411eda9
Compare
Choose a tag to compare

Release Notes

  • Bump github.com/go-stomp/stomp (#425) [98a310c]
  • Use a tcp readiness probe instead of cli command (#410) [01b3683]
  • Merge pull request #422 from rabbitmq/rename-erlang-port [7b4de78]
  • Rename cluster-links to cluster-rpc in headless service. [155a965]
  • Set topologySpreadConstraints by default [4d3d3db]
  • Merge pull request #421 from rabbitmq/disk-limit [7d080b4]
  • Set disk free space limit to 2GB by default [4a2faae]
  • Merge pull request #407 from rabbitmq/dependabot/go_modules/github.com/cloudflare/cfssl-1.5.0 [88efbd0]
  • Bump github.com/cloudflare/cfssl from 1.4.1 to 1.5.0 [45081a2]
  • Omit replicas from encoding when empty (#405) [572a285]
  • Add rabbit memory limit (#403) [396e5c6]
  • Merge pull request #394 from rabbitmq/configuration-updates [73233e7]
  • Consistent variable naming in integration tests [b131459]
  • Remove redundent and wrong assertion [ffe8a0d]
  • Merge pull request #400 from rabbitmq/imagePullSecrets [eee6aba]
  • Use most appropriate matcher [25d2528]
  • Remove duplicate code [a1d63dd]
  • Wait for status ClusterAvailable to be updated [5228979]
  • Increase timeout for config map annotation [f3cf78a]
  • Change spec.imagePullSecrets to spec.imagePullSecrets [0bcfb64]
  • Make replicas optional (#393) [7bb5e4e]
  • Use DescribeTable in server config updates integration-tests [9a481bc]
  • Rename configmaps const names to be more explicit [7ae8c5b]
  • Remove unused method UpdateRequiresStsRestart [63ea25c]
  • Ensure rabbit server configurations by using timestamp annotations [d70e0c3]
  • Add K8s version to system test names [e33d7a6]
  • Rephrase some controller comments [e317c24]
  • Merge pull request #391 from rabbitmq/dependabot/go_modules/github.com/onsi/ginkgo-1.14.2 [df0c630]
  • Merge pull request #386 from rabbitmq/system-tests-mqtt [1e91931]
  • Bump github.com/onsi/ginkgo from 1.14.1 to 1.14.2 [b0cb970]
  • Merge pull request #388 from rabbitmq/rename-admin-to-defaultuser [4c87d13]
  • Merge pull request #390 from rabbitmq/dependabot/go_modules/github.com/onsi/gomega-1.10.3 [162eb6b]
  • Merge pull request #389 from rabbitmq/defaulting [039848e]
  • Add defaulting unit tests for spec.service.type and spec.persistence.storage [ffdfc71]
  • Use CRD defaulting [cd26b91]
  • Allow users to automatically run rabbitmq-queues rebalance all after cluster restarts (#385) [fd611cd]
  • Do not expect success on token timeout [48d2f01]
  • Bump github.com/onsi/gomega from 1.10.2 to 1.10.3 [7116040]
  • Rename admin to default user [a3ab4b0]
  • Move exported Build and Update functions to the top [c6c8ccf]

0.47.0

08 Oct 15:08
008183c
Compare
Choose a tag to compare

Highlights

  • Mount configuration files as projected keys [67b10d1]
  • Put nodes into maintenance mode in preStop hook (#378) [e12a397]
  • Descriptions in nested structures in .spec.override are stripped, considerably reducing the size of the CRD #369

Release Notes

  • Merge pull request #382 from rabbitmq/projected-keys-361 [008183c]
  • Merge pull request #384 from rabbitmq/dependabot/go_modules/gopkg.in/ini.v1-1.62.0 [9489e51]
  • Mount configuration files as projected keys [67b10d1]
  • Put nodes into maintenance mode in preStop hook (#378) [e12a397]
  • Hacky way to remove override descriptions (#383) [cce318f]
  • Bump gopkg.in/ini.v1 from 1.61.0 to 1.62.0 [b818263]
  • Merge pull request #339 from rabbitmq/dependabot/go_modules/sigs.k8s.io/kind-0.9.0 [9163dc1]
  • Update rabbitmq to 3.8.9 (#380) [2e10074]
  • Merge pull request #376 from rabbitmq/error-check-admin-secret [ad30e19]
  • Merge pull request #377 from rabbitmq/controller-refactors [03cab12]
  • Merge pull request #375 from rabbitmq/system-tests-refactors [57bd805]
  • Set owner reference in builders instead of controller [0152d48]
  • Check returned error by WriteTo [45980e3]
  • Remove unnecessary requeue [00b5c53]
  • Merge pull request #373 from rabbitmq/remove-ci-overlay-sample [f064344]
  • Remove unnecessary const declaration in sys tests [206e217]
  • Remove repetitive value assignments in system tests [a0ba1d4]
  • Remove unnecessary ci overlay in config/sample [7fca03f]
  • Proposal to reduce size of CRD (#365) [175ac9b]
  • Merge pull request #360 from rabbitmq/kubectl-plugin-storage [6e86482]
  • set maxDescLen to 0 to remove descriptions (#371) [3181916]
  • Merge pull request #370 from rabbitmq/stale-automation [766aca9]
  • Promote 'stale' GitHub action to non-debug mode [ef801ac]
  • Merge pull request #367 from rabbitmq/stale-automation [742c08f]
  • Add automation to auto-mark issues & PRs as stale [c16ceb0]
  • New command to enable all feature flags (#364) [9bb6f8c]
  • Reflect new release frequency in versioning KEP (#359) [6d1dd02]
  • Support for storage class name in kubectl plugin [e8bdfe6]
  • Run system tests on 3 Kubernetes versions [dd5577e]
  • New quick start (#358) [9b821d3]
  • Bump sigs.k8s.io/kind from 0.8.1 to 0.9.0 [d01bca4]

0.46.0

23 Sep 14:27
56e2f09
Compare
Choose a tag to compare

Release Notes

  • Merge pull request #356 from rabbitmq/retry-logic-system-tests [56e2f09]
  • Add retry logic to MQTT/STOMP test suite [9eef51c]
  • Merge pull request #355 from rabbitmq/rename-registry [5c2fae9]
  • Update registry reference to new registry [5ad4b4b]
  • Simplify installation method in kubectl-rabbitmq [d5444f5]
  • Merge pull request #346 from rabbitmq/340-default-user-pass [6a8a87e]
  • Minor rewording [0d5b4fb]
  • Change admin secret to projected volume [706cf8f]
  • Fix double-encoding of config file and update README with min RMQ version [df0fab0]
  • Correct admin secret volumes [0bce98a]
  • Configure default user/password through conf.d [c39b820]

0.44.0

21 Sep 12:39
3d1219d
Compare
Choose a tag to compare

Release Notes

  • Merge pull request #347 from rabbitmq/registry-references-338 [3d1219d]
  • Update registry references to new name [da9ee52]