You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by as...@apache.org on 2021/11/25 07:57:05 UTC

[camel-k] branch main updated (be41340 -> bb51a99)

This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a change to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git.


    from be41340  Updated CHANGELOG.md
     new 2ec9775  chore(lint): as the lint target is not used in CI, switch to a simple and less verbose output format
     new bc66d73  chore(lint): remove unused lint configurations
     new 0139d21  fix(lint): net/http.Get must not be called (noctx)
     new 194ae8a  fix(lint): context should be propagated (contextcheck)
     new d210c02  fix(lint): comment should end in a period
     new bb51a99  chore(lint): fix findings

The 6 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .golangci.yml                                      | 41 -----------
 addons/master/master.go                            |  4 +-
 addons/strimzi/duck/v1beta2/duck_types.go          | 12 ++--
 addons/strimzi/duck/v1beta2/register.go            |  8 +--
 addons/strimzi/strimzi.go                          |  2 +-
 addons/threescale/3scale.go                        | 24 +++----
 addons/tracing/discovery/jaeger.go                 |  2 +-
 addons/tracing/discovery/locator.go                |  4 +-
 addons/tracing/tracing.go                          |  4 +-
 cmd/util/doc-gen/generators/generators.go          |  4 +-
 cmd/util/doc-gen/generators/traitdocgen.go         |  4 +-
 cmd/util/doc-gen/generators/traitmetadatagen.go    |  4 +-
 cmd/util/vfs-gen/main.go                           |  4 +-
 pkg/apis/apis.go                                   |  4 +-
 pkg/builder/kaniko.go                              |  2 +-
 pkg/builder/s2i.go                                 |  1 +
 pkg/builder/types.go                               | 10 +--
 pkg/client/client.go                               | 18 ++---
 pkg/cmd/bind.go                                    |  2 +-
 pkg/cmd/builder/builder.go                         |  2 +-
 pkg/cmd/delete.go                                  |  2 +-
 pkg/cmd/modeline.go                                |  6 +-
 pkg/cmd/operator/operator.go                       |  4 +-
 pkg/cmd/root.go                                    | 10 +--
 pkg/cmd/run.go                                     | 10 +--
 pkg/cmd/run_help.go                                | 44 ++++++------
 pkg/cmd/util.go                                    |  4 +-
 pkg/cmd/util_commands.go                           |  4 +-
 pkg/cmd/util_config.go                             | 20 +++---
 pkg/cmd/util_content.go                            | 37 +++++-----
 pkg/cmd/util_content_test.go                       | 31 ++++++--
 pkg/cmd/util_dependencies.go                       |  6 +-
 pkg/cmd/util_sources.go                            | 12 ++--
 pkg/cmd/version.go                                 |  2 +-
 pkg/controller/build/action.go                     |  2 +-
 pkg/controller/build/build_controller.go           |  2 +-
 pkg/controller/build/error.go                      |  6 +-
 pkg/controller/build/initialize_pod.go             |  6 +-
 pkg/controller/build/initialize_routine.go         |  6 +-
 pkg/controller/build/log.go                        |  2 +-
 pkg/controller/build/monitor_pod.go                |  6 +-
 pkg/controller/build/monitor_routine.go            |  8 ++-
 pkg/controller/build/schedule.go                   |  6 +-
 pkg/controller/controller.go                       |  4 +-
 pkg/controller/integration/action.go               |  2 +-
 pkg/controller/integration/initialize.go           |  8 +--
 .../integration/integration_controller.go          |  2 +-
 pkg/controller/integration/kits.go                 |  6 +-
 pkg/controller/integration/log.go                  |  2 +-
 pkg/controller/integration/monitor.go              |  2 +-
 pkg/controller/integration/platform_setup.go       | 10 +--
 pkg/controller/integrationkit/action.go            |  2 +-
 pkg/controller/integrationkit/build.go             |  2 +-
 pkg/controller/integrationkit/error.go             |  2 +-
 pkg/controller/integrationkit/initialize.go        |  2 +-
 .../integrationkit/integrationkit_controller.go    |  6 +-
 pkg/controller/integrationkit/log.go               |  2 +-
 pkg/controller/integrationkit/monitor.go           |  2 +-
 pkg/controller/integrationplatform/action.go       |  2 +-
 pkg/controller/integrationplatform/create.go       |  2 +-
 pkg/controller/integrationplatform/initialize.go   |  2 +-
 .../integrationplatform_controller.go              |  6 +-
 pkg/controller/integrationplatform/log.go          |  2 +-
 pkg/controller/integrationplatform/monitor.go      |  2 +-
 pkg/controller/kamelet/action.go                   |  2 +-
 pkg/controller/kamelet/initialize.go               |  2 +-
 pkg/controller/kamelet/kamelet_controller.go       |  2 +-
 pkg/controller/kamelet/log.go                      |  2 +-
 pkg/controller/kamelet/monitor.go                  |  2 +-
 pkg/controller/kameletbinding/action.go            |  2 +-
 pkg/controller/kameletbinding/initialize.go        |  2 +-
 .../kameletbinding/kamelet_binding_controller.go   |  2 +-
 pkg/controller/kameletbinding/log.go               |  2 +-
 pkg/controller/kameletbinding/monitor.go           |  2 +-
 pkg/event/manager.go                               | 62 ++++++++--------
 pkg/install/builder.go                             |  2 +-
 pkg/install/common.go                              |  8 +--
 pkg/install/kamelets.go                            |  4 +-
 pkg/install/openshift.go                           | 12 ++--
 pkg/install/operator.go                            |  2 +-
 pkg/install/optional.go                            |  2 +-
 pkg/install/secret.go                              |  6 +-
 pkg/metadata/metadata.go                           |  6 +-
 pkg/metadata/types.go                              |  2 +-
 pkg/platform/defaults.go                           |  2 +-
 pkg/platform/operator.go                           | 12 ++--
 pkg/platform/platform.go                           | 22 +++---
 pkg/platform/resources.go                          |  8 +--
 pkg/resources/resources_support.go                 | 12 ++--
 pkg/trait/affinity.go                              |  2 +-
 pkg/trait/builder.go                               |  6 +-
 pkg/trait/camel.go                                 |  4 +-
 pkg/trait/container.go                             |  2 +-
 pkg/trait/cron.go                                  | 12 ++--
 pkg/trait/dependencies.go                          |  4 +-
 pkg/trait/dependencies_test.go                     |  2 +-
 pkg/trait/deployer.go                              |  6 +-
 pkg/trait/deployment.go                            |  4 +-
 pkg/trait/environment.go                           |  4 +-
 pkg/trait/error_handler.go                         |  4 +-
 pkg/trait/gc.go                                    |  2 +-
 pkg/trait/health.go                                |  2 +-
 pkg/trait/ingress.go                               |  4 +-
 pkg/trait/istio.go                                 |  2 +-
 pkg/trait/jvm.go                                   |  4 +-
 pkg/trait/kamelets.go                              |  4 +-
 pkg/trait/knative.go                               |  4 +-
 pkg/trait/knative_service.go                       |  8 +--
 pkg/trait/logging.go                               |  2 +-
 pkg/trait/openapi.go                               |  4 +-
 pkg/trait/owner.go                                 |  4 +-
 pkg/trait/pdb.go                                   |  2 +-
 pkg/trait/platform.go                              |  6 +-
 pkg/trait/pod.go                                   |  2 +-
 pkg/trait/prometheus.go                            |  2 +-
 pkg/trait/pull_secret.go                           |  2 +-
 pkg/trait/quarkus.go                               |  6 +-
 pkg/trait/route.go                                 |  2 +-
 pkg/trait/service.go                               |  4 +-
 pkg/trait/service_binding.go                       |  2 +-
 pkg/trait/toleration.go                            |  2 +-
 pkg/trait/trait.go                                 |  2 +-
 pkg/trait/trait_catalog.go                         |  8 +--
 pkg/trait/trait_factory.go                         |  6 +-
 pkg/trait/trait_types.go                           | 34 ++++-----
 pkg/trait/util.go                                  |  8 +--
 pkg/util/bindings/api.go                           |  4 +-
 pkg/util/bindings/catalog.go                       |  2 +-
 pkg/util/bindings/kamelet.go                       |  2 +-
 pkg/util/camel/camel_dependencies.go               |  4 +-
 pkg/util/camel/camel_runtime.go                    |  2 +-
 pkg/util/camel/camel_runtime_catalog.go            | 22 +++---
 pkg/util/camel/camel_types.go                      |  4 +-
 pkg/util/camel/catalog.go                          |  2 +-
 pkg/util/cancellable/cancellable.go                |  6 +-
 pkg/util/digest/digest.go                          |  8 +--
 pkg/util/docker/docker.go                          | 12 ++--
 pkg/util/docker/docker_base.go                     | 38 +++++-----
 pkg/util/dsl/flow.go                               |  6 +-
 pkg/util/dsl/template.go                           |  2 +-
 pkg/util/envvar/envvar.go                          | 10 +--
 pkg/util/gzip/compress.go                          |  8 +--
 pkg/util/indentedwriter/writer.go                  | 12 ++--
 pkg/util/knative/apis.go                           | 10 +--
 pkg/util/knative/knative.go                        |  4 +-
 pkg/util/knative/uri.go                            |  8 +--
 pkg/util/kubernetes/camel.go                       |  6 +-
 pkg/util/kubernetes/client.go                      |  6 +-
 pkg/util/kubernetes/collection.go                  | 84 +++++++++++-----------
 pkg/util/kubernetes/customclient.go                |  2 +-
 pkg/util/kubernetes/factory.go                     |  6 +-
 pkg/util/kubernetes/loader.go                      |  4 +-
 pkg/util/kubernetes/log/annotation_scraper.go      |  6 +-
 pkg/util/kubernetes/log/pod_scraper.go             |  8 +--
 pkg/util/kubernetes/log/util.go                    |  4 +-
 pkg/util/kubernetes/lookup.go                      |  4 +-
 pkg/util/kubernetes/printer.go                     |  2 +-
 pkg/util/kubernetes/replace.go                     |  2 +-
 pkg/util/kubernetes/resolver.go                    | 10 +--
 pkg/util/kubernetes/sanitize.go                    |  4 +-
 pkg/util/kubernetes/util.go                        |  6 +-
 pkg/util/label/label.go                            |  4 +-
 pkg/util/log/log.go                                | 56 +++++++--------
 pkg/util/maven/maven_project.go                    | 12 ++--
 pkg/util/maven/maven_settings.go                   |  2 +-
 pkg/util/maven/maven_types.go                      | 10 +--
 pkg/util/minikube/registry.go                      |  2 +-
 pkg/util/modeline/types.go                         |  2 +-
 pkg/util/monitoring/register.go                    |  2 +-
 pkg/util/olm/operator.go                           | 22 +++---
 pkg/util/openshift/openshift.go                    |  2 +-
 pkg/util/openshift/register.go                     |  2 +-
 pkg/util/property/property.go                      |  6 +-
 pkg/util/registry/registry.go                      |  8 +--
 pkg/util/source/inspector.go                       | 10 +--
 pkg/util/source/inspector_xml.go                   |  4 +-
 pkg/util/source/inspector_yaml.go                  |  6 +-
 pkg/util/source/types.go                           |  4 +-
 pkg/util/sync/file.go                              |  2 +-
 pkg/util/test/assertions.go                        |  6 +-
 pkg/util/test/client.go                            |  8 +--
 pkg/util/uri/uri.go                                |  6 +-
 pkg/util/util.go                                   | 48 ++++++-------
 script/Makefile                                    |  4 +-
 184 files changed, 678 insertions(+), 692 deletions(-)

[camel-k] 06/06: chore(lint): fix findings

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit bb51a9984e0d58aa134b110fc212c9d30d9b1788
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 16:05:05 2021 +0100

    chore(lint): fix findings
---
 pkg/cmd/run.go               |  4 ++--
 pkg/cmd/run_help.go          | 16 ++++++++--------
 pkg/cmd/util_content_test.go | 12 ++++++------
 3 files changed, 16 insertions(+), 16 deletions(-)

diff --git a/pkg/cmd/run.go b/pkg/cmd/run.go
index ba01178..153c13c 100644
--- a/pkg/cmd/run.go
+++ b/pkg/cmd/run.go
@@ -570,7 +570,7 @@ func (o *runCmdOptions) createOrUpdateIntegration(cmd *cobra.Command, c client.C
 
 	for _, resource := range o.Resources {
 		if config, parseErr := ParseResourceOption(resource); parseErr == nil {
-			if applyResourceOptionErr := ApplyResourceOption(config, &integration.Spec, c, namespace, o.Compression); applyResourceOptionErr != nil {
+			if applyResourceOptionErr := ApplyResourceOption(o.Context, config, &integration.Spec, c, namespace, o.Compression); applyResourceOptionErr != nil {
 				return nil, applyResourceOptionErr
 			}
 		} else {
@@ -621,7 +621,7 @@ func (o *runCmdOptions) createOrUpdateIntegration(cmd *cobra.Command, c client.C
 
 	for _, item := range o.Configs {
 		if config, parseErr := ParseConfigOption(item); parseErr == nil {
-			if applyConfigOptionErr := ApplyConfigOption(config, &integration.Spec, c, namespace, o.Compression); applyConfigOptionErr != nil {
+			if applyConfigOptionErr := ApplyConfigOption(o.Context, config, &integration.Spec, c, namespace, o.Compression); applyConfigOptionErr != nil {
 				return nil, applyConfigOptionErr
 			}
 		} else {
diff --git a/pkg/cmd/run_help.go b/pkg/cmd/run_help.go
index 9521555..5104ac9 100644
--- a/pkg/cmd/run_help.go
+++ b/pkg/cmd/run_help.go
@@ -181,11 +181,11 @@ func parseOption(item string) (*RunConfigOption, error) {
 	return configurationOption, nil
 }
 
-func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
+func applyOption(ctx context.Context, config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 	c client.Client, namespace string, enableCompression bool, resourceType v1.ResourceType) error {
 	switch config.configType {
 	case ConfigOptionTypeConfigmap:
-		cm := kubernetes.LookupConfigmap(context.Background(), c, namespace, config.Name())
+		cm := kubernetes.LookupConfigmap(ctx, c, namespace, config.Name())
 		if cm == nil {
 			fmt.Printf("Warn: %s Configmap not found in %s namespace, make sure to provide it before the Integration can run\n",
 				config.Name(), namespace)
@@ -194,7 +194,7 @@ func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 		}
 		integrationSpec.AddConfigurationAsResource(config.Type(), config.Name(), string(resourceType), config.DestinationPath(), config.Key())
 	case ConfigOptionTypeSecret:
-		secret := kubernetes.LookupSecret(context.Background(), c, namespace, config.Name())
+		secret := kubernetes.LookupSecret(ctx, c, namespace, config.Name())
 		if secret == nil {
 			fmt.Printf("Warn: %s Secret not found in %s namespace, make sure to provide it before the Integration can run\n",
 				config.Name(), namespace)
@@ -210,7 +210,7 @@ func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 			return fmt.Errorf("you cannot provide a file larger than 1 MB (it was %s MB), check configmap option or --volume instead", printSize)
 		}
 		// Don't allow a binary non compressed resource
-		rawData, contentType, err := loadRawContent(context.Background(), config.Name())
+		rawData, contentType, err := loadRawContent(ctx, config.Name())
 		if err != nil {
 			return err
 		}
@@ -231,17 +231,17 @@ func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 }
 
 // ApplyConfigOption will set the proper --config option behavior to the IntegrationSpec.
-func ApplyConfigOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
+func ApplyConfigOption(ctx context.Context, config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
 	// A config option cannot specify destination path
 	if config.DestinationPath() != "" {
 		return fmt.Errorf("cannot specify a destination path for this option type")
 	}
-	return applyOption(config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeConfig)
+	return applyOption(ctx, config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeConfig)
 }
 
 // ApplyResourceOption will set the proper --resource option behavior to the IntegrationSpec.
-func ApplyResourceOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
-	return applyOption(config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeData)
+func ApplyResourceOption(ctx context.Context, config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
+	return applyOption(ctx, config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeData)
 }
 
 func binaryOrTextResource(fileName string, data []byte, contentType string, base64Compression bool, resourceType v1.ResourceType, destinationPath string) (v1.ResourceSpec, error) {
diff --git a/pkg/cmd/util_content_test.go b/pkg/cmd/util_content_test.go
index 388c867..a0548c0 100644
--- a/pkg/cmd/util_content_test.go
+++ b/pkg/cmd/util_content_test.go
@@ -31,7 +31,7 @@ import (
 )
 
 func TestRawContentFileMissing(t *testing.T) {
-	_, _, err := loadRawContent(context.TODO(), "dsadas")
+	_, _, err := loadRawContent(context.Background(), "dsadas")
 	assert.NotNil(t, err)
 }
 
@@ -44,7 +44,7 @@ func TestRawBinaryContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte{1, 2, 3, 4, 5, 6}, 0o400))
 
-	data, contentType, err := loadRawContent(context.TODO(), tmpFile.Name())
+	data, contentType, err := loadRawContent(context.Background(), tmpFile.Name())
 	assert.Nil(t, err)
 	assert.Equal(t, []byte{1, 2, 3, 4, 5, 6}, data)
 	assert.True(t, isBinary(contentType))
@@ -59,7 +59,7 @@ func TestRawApplicationContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, err := loadRawContent(context.TODO(), tmpFile.Name())
+	data, contentType, err := loadRawContent(context.Background(), tmpFile.Name())
 	assert.Nil(t, err)
 	assert.Equal(t, `{"hello":"world"}`, string(data))
 	assert.False(t, isBinary(contentType))
@@ -74,7 +74,7 @@ func TestTextContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, compressed, err := loadTextContent(context.TODO(), tmpFile.Name(), false)
+	data, contentType, compressed, err := loadTextContent(context.Background(), tmpFile.Name(), false)
 	assert.Nil(t, err)
 	assert.Equal(t, `{"hello":"world"}`, data)
 	assert.False(t, isBinary(contentType))
@@ -90,7 +90,7 @@ func TestTextCompressed(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, compressed, err := loadTextContent(context.TODO(), tmpFile.Name(), true)
+	data, contentType, compressed, err := loadTextContent(context.Background(), tmpFile.Name(), true)
 	assert.Nil(t, err)
 	assert.NotEqual(t, `{"hello":"world"}`, data)
 	assert.False(t, isBinary(contentType))
@@ -113,7 +113,7 @@ func TestContentHttp(t *testing.T) {
 	u, err := url.Parse(svr.URL)
 	assert.Nil(t, err)
 
-	data, err := loadContentHTTP(context.TODO(), u)
+	data, err := loadContentHTTP(context.Background(), u)
 	assert.Nil(t, err)
 	assert.NotEmpty(t, data)
 	assert.Equal(t, expected, string(data))

[camel-k] 03/06: fix(lint): net/http.Get must not be called (noctx)

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit 0139d21f9d3c4abf3569bc4ec3400a5430b0a00e
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 14:39:07 2021 +0100

    fix(lint): net/http.Get must not be called (noctx)
---
 .golangci.yml                |  1 -
 pkg/cmd/util_content.go      | 19 +++++++++++--------
 pkg/cmd/util_content_test.go | 20 ++++++++++++++++++++
 3 files changed, 31 insertions(+), 9 deletions(-)

diff --git a/.golangci.yml b/.golangci.yml
index 490d6da..c9af8be 100644
--- a/.golangci.yml
+++ b/.golangci.yml
@@ -54,7 +54,6 @@ linters:
     - nlreturn
     - nilnil
     - exhaustive
-    - noctx
     - nakedret
     - contextcheck
     - maligned
diff --git a/pkg/cmd/util_content.go b/pkg/cmd/util_content.go
index 289621e..0ec57a4 100644
--- a/pkg/cmd/util_content.go
+++ b/pkg/cmd/util_content.go
@@ -18,8 +18,9 @@ limitations under the License.
 package cmd
 
 import (
+	"context"
 	"fmt"
-	"io/ioutil"
+	"io"
 	"net/http"
 	"net/url"
 	"os"
@@ -101,7 +102,14 @@ func loadTextContent(source string, base64Compression bool) (string, string, boo
 }
 
 func loadContentHTTP(u fmt.Stringer) ([]byte, error) {
-	resp, err := http.Get(u.String())
+	req, err := http.NewRequestWithContext(context.Background(), http.MethodGet, u.String(), nil)
+	if err != nil {
+		return nil, err
+	}
+
+	c := &http.Client{}
+
+	resp, err := c.Do(req)
 	if err != nil {
 		return []byte{}, err
 	}
@@ -113,12 +121,7 @@ func loadContentHTTP(u fmt.Stringer) ([]byte, error) {
 		return []byte{}, fmt.Errorf("the provided URL %s is not reachable, error code is %d", u.String(), resp.StatusCode)
 	}
 
-	content, err := ioutil.ReadAll(resp.Body)
-	if err != nil {
-		return []byte{}, err
-	}
-
-	return content, nil
+	return io.ReadAll(resp.Body)
 }
 
 func loadContentGitHub(u *url.URL) ([]byte, error) {
diff --git a/pkg/cmd/util_content_test.go b/pkg/cmd/util_content_test.go
index ae34b1d..5684ac8 100644
--- a/pkg/cmd/util_content_test.go
+++ b/pkg/cmd/util_content_test.go
@@ -18,7 +18,11 @@ limitations under the License.
 package cmd
 
 import (
+	"fmt"
 	"io/ioutil"
+	"net/http"
+	"net/http/httptest"
+	"net/url"
 	"os"
 	"testing"
 
@@ -97,3 +101,19 @@ func TestIsBinary(t *testing.T) {
 	assert.True(t, isBinary("application/zip"))
 	assert.False(t, isBinary("text/plain"))
 }
+
+func TestContentHttp(t *testing.T) {
+	expected := "the content"
+	svr := httptest.NewServer(http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
+		_, _ = fmt.Fprintf(w, expected)
+	}))
+	defer svr.Close()
+
+	u, err := url.Parse(svr.URL)
+	assert.Nil(t, err)
+
+	data, err := loadContentHTTP(u)
+	assert.Nil(t, err)
+	assert.NotEmpty(t, data)
+	assert.Equal(t, expected, string(data))
+}

[camel-k] 01/06: chore(lint): as the lint target is not used in CI, switch to a simple and less verbose output format

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit 2ec977514d977f5c6e23ec69a4ef5bb464a66ae7
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 14:51:41 2021 +0100

    chore(lint): as the lint target is not used in CI, switch to a simple and less verbose output format
---
 script/Makefile | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/script/Makefile b/script/Makefile
index 6e2fa27..10660ec 100644
--- a/script/Makefile
+++ b/script/Makefile
@@ -273,10 +273,10 @@ dep:
 	go mod tidy
 
 lint:
-	GOGC=$(LINT_GOGC) golangci-lint run --verbose --deadline $(LINT_DEADLINE)
+	GOGC=$(LINT_GOGC) golangci-lint run --out-format tab --deadline $(LINT_DEADLINE)
 
 lint-fix:
-	GOGC=$(LINT_GOGC) golangci-lint run --verbose --deadline $(LINT_DEADLINE) --fix
+	GOGC=$(LINT_GOGC) golangci-lint run --out-format tab --deadline $(LINT_DEADLINE) --fix
 
 
 check-licenses:

[camel-k] 05/06: fix(lint): comment should end in a period

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit d210c02807217e684f020b6ab87112b4e5402d58
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 15:48:51 2021 +0100

    fix(lint): comment should end in a period
---
 .golangci.yml                                      |  1 -
 addons/master/master.go                            |  4 +-
 addons/strimzi/duck/v1beta2/duck_types.go          | 12 ++--
 addons/strimzi/duck/v1beta2/register.go            |  8 +--
 addons/strimzi/strimzi.go                          |  2 +-
 addons/threescale/3scale.go                        | 24 +++----
 addons/tracing/discovery/jaeger.go                 |  2 +-
 addons/tracing/discovery/locator.go                |  4 +-
 addons/tracing/tracing.go                          |  4 +-
 cmd/util/doc-gen/generators/generators.go          |  4 +-
 cmd/util/doc-gen/generators/traitdocgen.go         |  4 +-
 cmd/util/doc-gen/generators/traitmetadatagen.go    |  4 +-
 cmd/util/vfs-gen/main.go                           |  4 +-
 pkg/apis/apis.go                                   |  4 +-
 pkg/builder/kaniko.go                              |  2 +-
 pkg/builder/types.go                               | 10 +--
 pkg/client/client.go                               | 18 ++---
 pkg/cmd/bind.go                                    |  2 +-
 pkg/cmd/builder/builder.go                         |  2 +-
 pkg/cmd/delete.go                                  |  2 +-
 pkg/cmd/modeline.go                                |  6 +-
 pkg/cmd/operator/operator.go                       |  4 +-
 pkg/cmd/root.go                                    | 10 +--
 pkg/cmd/run_help.go                                | 28 ++++----
 pkg/cmd/util.go                                    |  4 +-
 pkg/cmd/util_commands.go                           |  4 +-
 pkg/cmd/util_config.go                             | 20 +++---
 pkg/cmd/util_sources.go                            |  6 +-
 pkg/cmd/version.go                                 |  2 +-
 pkg/controller/build/action.go                     |  2 +-
 pkg/controller/build/build_controller.go           |  2 +-
 pkg/controller/build/error.go                      |  6 +-
 pkg/controller/build/initialize_pod.go             |  6 +-
 pkg/controller/build/initialize_routine.go         |  6 +-
 pkg/controller/build/log.go                        |  2 +-
 pkg/controller/build/monitor_pod.go                |  6 +-
 pkg/controller/build/monitor_routine.go            |  6 +-
 pkg/controller/build/schedule.go                   |  6 +-
 pkg/controller/controller.go                       |  4 +-
 pkg/controller/integration/action.go               |  2 +-
 pkg/controller/integration/initialize.go           |  8 +--
 .../integration/integration_controller.go          |  2 +-
 pkg/controller/integration/kits.go                 |  6 +-
 pkg/controller/integration/log.go                  |  2 +-
 pkg/controller/integration/monitor.go              |  2 +-
 pkg/controller/integration/platform_setup.go       | 10 +--
 pkg/controller/integrationkit/action.go            |  2 +-
 pkg/controller/integrationkit/build.go             |  2 +-
 pkg/controller/integrationkit/error.go             |  2 +-
 pkg/controller/integrationkit/initialize.go        |  2 +-
 .../integrationkit/integrationkit_controller.go    |  6 +-
 pkg/controller/integrationkit/log.go               |  2 +-
 pkg/controller/integrationkit/monitor.go           |  2 +-
 pkg/controller/integrationplatform/action.go       |  2 +-
 pkg/controller/integrationplatform/create.go       |  2 +-
 pkg/controller/integrationplatform/initialize.go   |  2 +-
 .../integrationplatform_controller.go              |  6 +-
 pkg/controller/integrationplatform/log.go          |  2 +-
 pkg/controller/integrationplatform/monitor.go      |  2 +-
 pkg/controller/kamelet/action.go                   |  2 +-
 pkg/controller/kamelet/initialize.go               |  2 +-
 pkg/controller/kamelet/kamelet_controller.go       |  2 +-
 pkg/controller/kamelet/log.go                      |  2 +-
 pkg/controller/kamelet/monitor.go                  |  2 +-
 pkg/controller/kameletbinding/action.go            |  2 +-
 pkg/controller/kameletbinding/initialize.go        |  2 +-
 .../kameletbinding/kamelet_binding_controller.go   |  2 +-
 pkg/controller/kameletbinding/log.go               |  2 +-
 pkg/controller/kameletbinding/monitor.go           |  2 +-
 pkg/event/manager.go                               | 62 ++++++++--------
 pkg/install/builder.go                             |  2 +-
 pkg/install/common.go                              |  8 +--
 pkg/install/kamelets.go                            |  4 +-
 pkg/install/openshift.go                           | 12 ++--
 pkg/install/operator.go                            |  2 +-
 pkg/install/optional.go                            |  2 +-
 pkg/install/secret.go                              |  6 +-
 pkg/metadata/metadata.go                           |  6 +-
 pkg/metadata/types.go                              |  2 +-
 pkg/platform/defaults.go                           |  2 +-
 pkg/platform/operator.go                           | 12 ++--
 pkg/platform/platform.go                           | 22 +++---
 pkg/platform/resources.go                          |  8 +--
 pkg/resources/resources_support.go                 | 12 ++--
 pkg/trait/affinity.go                              |  2 +-
 pkg/trait/builder.go                               |  6 +-
 pkg/trait/camel.go                                 |  4 +-
 pkg/trait/container.go                             |  2 +-
 pkg/trait/cron.go                                  | 12 ++--
 pkg/trait/dependencies.go                          |  4 +-
 pkg/trait/dependencies_test.go                     |  2 +-
 pkg/trait/deployer.go                              |  6 +-
 pkg/trait/deployment.go                            |  4 +-
 pkg/trait/environment.go                           |  4 +-
 pkg/trait/error_handler.go                         |  4 +-
 pkg/trait/gc.go                                    |  2 +-
 pkg/trait/health.go                                |  2 +-
 pkg/trait/ingress.go                               |  4 +-
 pkg/trait/istio.go                                 |  2 +-
 pkg/trait/jvm.go                                   |  4 +-
 pkg/trait/kamelets.go                              |  4 +-
 pkg/trait/knative.go                               |  4 +-
 pkg/trait/knative_service.go                       |  8 +--
 pkg/trait/logging.go                               |  2 +-
 pkg/trait/openapi.go                               |  4 +-
 pkg/trait/owner.go                                 |  4 +-
 pkg/trait/pdb.go                                   |  2 +-
 pkg/trait/platform.go                              |  6 +-
 pkg/trait/pod.go                                   |  2 +-
 pkg/trait/prometheus.go                            |  2 +-
 pkg/trait/pull_secret.go                           |  2 +-
 pkg/trait/quarkus.go                               |  6 +-
 pkg/trait/route.go                                 |  2 +-
 pkg/trait/service.go                               |  4 +-
 pkg/trait/service_binding.go                       |  2 +-
 pkg/trait/toleration.go                            |  2 +-
 pkg/trait/trait.go                                 |  2 +-
 pkg/trait/trait_catalog.go                         |  8 +--
 pkg/trait/trait_factory.go                         |  6 +-
 pkg/trait/trait_types.go                           | 34 ++++-----
 pkg/trait/util.go                                  |  8 +--
 pkg/util/bindings/api.go                           |  4 +-
 pkg/util/bindings/catalog.go                       |  2 +-
 pkg/util/bindings/kamelet.go                       |  2 +-
 pkg/util/camel/camel_dependencies.go               |  4 +-
 pkg/util/camel/camel_runtime.go                    |  2 +-
 pkg/util/camel/camel_runtime_catalog.go            | 22 +++---
 pkg/util/camel/camel_types.go                      |  4 +-
 pkg/util/cancellable/cancellable.go                |  6 +-
 pkg/util/digest/digest.go                          |  8 +--
 pkg/util/docker/docker.go                          | 12 ++--
 pkg/util/docker/docker_base.go                     | 38 +++++-----
 pkg/util/dsl/flow.go                               |  6 +-
 pkg/util/dsl/template.go                           |  2 +-
 pkg/util/envvar/envvar.go                          | 10 +--
 pkg/util/gzip/compress.go                          |  8 +--
 pkg/util/indentedwriter/writer.go                  | 12 ++--
 pkg/util/knative/apis.go                           | 10 +--
 pkg/util/knative/knative.go                        |  4 +-
 pkg/util/knative/uri.go                            |  8 +--
 pkg/util/kubernetes/camel.go                       |  6 +-
 pkg/util/kubernetes/client.go                      |  6 +-
 pkg/util/kubernetes/collection.go                  | 84 +++++++++++-----------
 pkg/util/kubernetes/customclient.go                |  2 +-
 pkg/util/kubernetes/factory.go                     |  6 +-
 pkg/util/kubernetes/loader.go                      |  4 +-
 pkg/util/kubernetes/log/annotation_scraper.go      |  6 +-
 pkg/util/kubernetes/log/pod_scraper.go             |  8 +--
 pkg/util/kubernetes/log/util.go                    |  4 +-
 pkg/util/kubernetes/lookup.go                      |  4 +-
 pkg/util/kubernetes/printer.go                     |  2 +-
 pkg/util/kubernetes/replace.go                     |  2 +-
 pkg/util/kubernetes/resolver.go                    | 10 +--
 pkg/util/kubernetes/sanitize.go                    |  4 +-
 pkg/util/kubernetes/util.go                        |  6 +-
 pkg/util/label/label.go                            |  4 +-
 pkg/util/log/log.go                                | 56 +++++++--------
 pkg/util/maven/maven_project.go                    | 12 ++--
 pkg/util/maven/maven_settings.go                   |  2 +-
 pkg/util/maven/maven_types.go                      | 10 +--
 pkg/util/minikube/registry.go                      |  2 +-
 pkg/util/modeline/types.go                         |  2 +-
 pkg/util/monitoring/register.go                    |  2 +-
 pkg/util/olm/operator.go                           | 22 +++---
 pkg/util/openshift/openshift.go                    |  2 +-
 pkg/util/openshift/register.go                     |  2 +-
 pkg/util/property/property.go                      |  6 +-
 pkg/util/registry/registry.go                      |  8 +--
 pkg/util/source/inspector.go                       | 10 +--
 pkg/util/source/inspector_xml.go                   |  4 +-
 pkg/util/source/inspector_yaml.go                  |  6 +-
 pkg/util/source/types.go                           |  4 +-
 pkg/util/sync/file.go                              |  2 +-
 pkg/util/test/assertions.go                        |  6 +-
 pkg/util/test/client.go                            |  8 +--
 pkg/util/uri/uri.go                                |  6 +-
 pkg/util/util.go                                   | 48 ++++++-------
 177 files changed, 607 insertions(+), 608 deletions(-)

diff --git a/.golangci.yml b/.golangci.yml
index e7eb670..881e344 100644
--- a/.golangci.yml
+++ b/.golangci.yml
@@ -31,7 +31,6 @@ linters:
     - gomnd
     - gochecknoinits
     - gocognit
-    - godot
     - lll
     - nestif
     - cyclop
diff --git a/addons/master/master.go b/addons/master/master.go
index f92fc1b..e7a2d60 100644
--- a/addons/master/master.go
+++ b/addons/master/master.go
@@ -41,7 +41,7 @@ import (
 // NOTE: this trait adds special permissions to the integration service account in order to read/write configmaps and read pods.
 // It's recommended to use a different service account than "default" when running the integration.
 //
-// +camel-k:trait=master
+// +camel-k:trait=master.
 type masterTrait struct {
 	trait.BaseTrait `property:",squash"`
 	// Enables automatic configuration of the trait.
@@ -64,7 +64,7 @@ type masterTrait struct {
 	delegateDependencies []string `json:"-"`
 }
 
-// NewMasterTrait --
+// NewMasterTrait --.
 func NewMasterTrait() trait.Trait {
 	return &masterTrait{
 		BaseTrait: trait.NewBaseTrait("master", trait.TraitOrderBeforeControllerCreation),
diff --git a/addons/strimzi/duck/v1beta2/duck_types.go b/addons/strimzi/duck/v1beta2/duck_types.go
index 7e23933..9caee47 100644
--- a/addons/strimzi/duck/v1beta2/duck_types.go
+++ b/addons/strimzi/duck/v1beta2/duck_types.go
@@ -36,7 +36,7 @@ const (
 // +genclient:noStatus
 // +kubebuilder:object:root=true
 
-// KafkaTopic is the duck of a KafkaTopic
+// KafkaTopic is the duck of a KafkaTopic.
 type KafkaTopic struct {
 	metav1.TypeMeta   `json:",inline"`
 	metav1.ObjectMeta `json:"metadata,omitempty"`
@@ -44,7 +44,7 @@ type KafkaTopic struct {
 
 // +kubebuilder:object:root=true
 
-// KafkaTopicList contains a list of KafkaTopic
+// KafkaTopicList contains a list of KafkaTopic.
 type KafkaTopicList struct {
 	metav1.TypeMeta `json:",inline"`
 	metav1.ListMeta `json:"metadata,omitempty"`
@@ -56,7 +56,7 @@ type KafkaTopicList struct {
 // +genclient:noStatus
 // +kubebuilder:object:root=true
 
-// Kafka is the duck of a Kafka
+// Kafka is the duck of a Kafka.
 type Kafka struct {
 	metav1.TypeMeta   `json:",inline"`
 	metav1.ObjectMeta `json:"metadata,omitempty"`
@@ -64,12 +64,12 @@ type Kafka struct {
 	Status KafkaStatus `json:"status,omitempty"`
 }
 
-// KafkaStatus contains the relevant info of the Kafka status
+// KafkaStatus contains the relevant info of the Kafka status.
 type KafkaStatus struct {
 	Listeners []KafkaStatusListener `json:"listeners,omitempty"`
 }
 
-// KafkaStatusListener contains listener information
+// KafkaStatusListener contains listener information.
 type KafkaStatusListener struct {
 	BootstrapServers string `json:"bootstrapServers,omitempty"`
 	Type             string `json:"type,omitempty"`
@@ -77,7 +77,7 @@ type KafkaStatusListener struct {
 
 // +kubebuilder:object:root=true
 
-// KafkaList contains a list of Kafka
+// KafkaList contains a list of Kafka.
 type KafkaList struct {
 	metav1.TypeMeta `json:",inline"`
 	metav1.ListMeta `json:"metadata,omitempty"`
diff --git a/addons/strimzi/duck/v1beta2/register.go b/addons/strimzi/duck/v1beta2/register.go
index c48a9fc..506c02d 100644
--- a/addons/strimzi/duck/v1beta2/register.go
+++ b/addons/strimzi/duck/v1beta2/register.go
@@ -24,17 +24,17 @@ import (
 )
 
 var (
-	// SchemeGroupVersion is group version used to register these objects
+	// SchemeGroupVersion is group version used to register these objects.
 	SchemeGroupVersion = schema.GroupVersion{Group: StrimziGroup, Version: StrimziVersion}
 
-	// SchemeBuilder is used to add go types to the GroupVersionKind scheme
+	// SchemeBuilder is used to add go types to the GroupVersionKind scheme.
 	SchemeBuilder = runtime.NewSchemeBuilder(addKnownTypes)
 
-	// AddToScheme is a shortcut to SchemeBuilder.AddToScheme
+	// AddToScheme is a shortcut to SchemeBuilder.AddToScheme.
 	AddToScheme = SchemeBuilder.AddToScheme
 )
 
-// Resource takes an unqualified resource and returns a Group qualified GroupResource
+// Resource takes an unqualified resource and returns a Group qualified GroupResource.
 func Resource(resource string) schema.GroupResource {
 	return SchemeGroupVersion.WithResource(resource).GroupResource()
 }
diff --git a/addons/strimzi/strimzi.go b/addons/strimzi/strimzi.go
index 5d2413a..244264f 100644
--- a/addons/strimzi/strimzi.go
+++ b/addons/strimzi/strimzi.go
@@ -30,7 +30,7 @@ import (
 	"k8s.io/apimachinery/pkg/runtime/schema"
 )
 
-// BindingProvider allows to connect to a Kafka topic via KameletBinding
+// BindingProvider allows to connect to a Kafka topic via KameletBinding.
 type BindingProvider struct {
 	Client internalclientset.Interface
 }
diff --git a/addons/threescale/3scale.go b/addons/threescale/3scale.go
index d05fcb6..a1ee7df 100644
--- a/addons/threescale/3scale.go
+++ b/addons/threescale/3scale.go
@@ -30,7 +30,7 @@ import (
 //
 // The 3scale trait is disabled by default.
 //
-// +camel-k:trait=3scale
+// +camel-k:trait=3scale.
 type threeScaleTrait struct {
 	trait.BaseTrait `property:",squash"`
 	// Enables automatic configuration of the trait.
@@ -46,33 +46,33 @@ type threeScaleTrait struct {
 }
 
 const (
-	// ThreeScaleSchemeAnnotation --
+	// ThreeScaleSchemeAnnotation --.
 	ThreeScaleSchemeAnnotation = "discovery.3scale.net/scheme"
-	// ThreeScaleSchemeDefaultValue --
+	// ThreeScaleSchemeDefaultValue --.
 	ThreeScaleSchemeDefaultValue = "http"
 
-	// ThreeScalePortAnnotation --
+	// ThreeScalePortAnnotation --.
 	ThreeScalePortAnnotation = "discovery.3scale.net/port"
-	// ThreeScalePortDefaultValue --
+	// ThreeScalePortDefaultValue --.
 	ThreeScalePortDefaultValue = 80
 
-	// ThreeScalePathAnnotation --
+	// ThreeScalePathAnnotation --.
 	ThreeScalePathAnnotation = "discovery.3scale.net/path"
-	// ThreeScalePathDefaultValue --
+	// ThreeScalePathDefaultValue --.
 	ThreeScalePathDefaultValue = "/"
 
-	// ThreeScaleDescriptionPathAnnotation --
+	// ThreeScaleDescriptionPathAnnotation --.
 	ThreeScaleDescriptionPathAnnotation = "discovery.3scale.net/description-path"
-	// ThreeScaleDescriptionPathDefaultValue --
+	// ThreeScaleDescriptionPathDefaultValue --.
 	ThreeScaleDescriptionPathDefaultValue = "/openapi.json"
 
-	// ThreeScaleDiscoveryLabel --
+	// ThreeScaleDiscoveryLabel --.
 	ThreeScaleDiscoveryLabel = "discovery.3scale.net"
-	// ThreeScaleDiscoveryLabelEnabled --
+	// ThreeScaleDiscoveryLabelEnabled --.
 	ThreeScaleDiscoveryLabelEnabled = "true"
 )
 
-// NewThreeScaleTrait --
+// NewThreeScaleTrait --.
 func NewThreeScaleTrait() trait.Trait {
 	return &threeScaleTrait{
 		BaseTrait: trait.NewBaseTrait("3scale", trait.TraitOrderPostProcessResources),
diff --git a/addons/tracing/discovery/jaeger.go b/addons/tracing/discovery/jaeger.go
index c111b51..25eeb7f 100644
--- a/addons/tracing/discovery/jaeger.go
+++ b/addons/tracing/discovery/jaeger.go
@@ -67,7 +67,7 @@ func (loc *JaegerTracingLocator) FindEndpoint(ctx context.Context, c client.Clie
 	return "", nil
 }
 
-// registering the locator
+// registering the locator.
 func init() {
 	TracingLocators = append(TracingLocators, &JaegerTracingLocator{}, &JaegerTracingLocator{allowHeadless: true})
 }
diff --git a/addons/tracing/discovery/locator.go b/addons/tracing/discovery/locator.go
index 1b85b31..bf2f752 100644
--- a/addons/tracing/discovery/locator.go
+++ b/addons/tracing/discovery/locator.go
@@ -25,10 +25,10 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// TracingLocators contains available tracing locators
+// TracingLocators contains available tracing locators.
 var TracingLocators []TracingLocator
 
-// TracingLocator is able to find the address of an available tracing endpoint
+// TracingLocator is able to find the address of an available tracing endpoint.
 type TracingLocator interface {
 	FindEndpoint(context.Context, client.Client, log.Logger, *trait.Environment) (string, error)
 }
diff --git a/addons/tracing/tracing.go b/addons/tracing/tracing.go
index f0aaf62..e1e6da6 100644
--- a/addons/tracing/tracing.go
+++ b/addons/tracing/tracing.go
@@ -31,7 +31,7 @@ import (
 //
 // The Tracing trait is disabled by default.
 //
-// +camel-k:trait=tracing
+// +camel-k:trait=tracing.
 type tracingTrait struct {
 	trait.BaseTrait `property:",squash"`
 	// Enables automatic configuration of the trait, including automatic discovery of the tracing endpoint.
@@ -68,7 +68,7 @@ var (
 	defaultSamplerParam = "1"
 )
 
-// NewTracingTrait --
+// NewTracingTrait --.
 func NewTracingTrait() trait.Trait {
 	return &tracingTrait{
 		BaseTrait: trait.NewBaseTrait("tracing", trait.TraitOrderBeforeControllerCreation),
diff --git a/cmd/util/doc-gen/generators/generators.go b/cmd/util/doc-gen/generators/generators.go
index 3919133..fffe829 100644
--- a/cmd/util/doc-gen/generators/generators.go
+++ b/cmd/util/doc-gen/generators/generators.go
@@ -26,7 +26,7 @@ import (
 	"k8s.io/gengo/namer"
 )
 
-// CustomArgs --
+// CustomArgs --.
 type CustomArgs struct {
 	DocDir      string
 	ResourceDir string
@@ -48,7 +48,7 @@ func DefaultNameSystem() string {
 	return "default"
 }
 
-// Packages --
+// Packages --.
 func Packages(context *generator.Context, arguments *args.GeneratorArgs) (packages generator.Packages) {
 	for _, i := range context.Inputs {
 		pkg := context.Universe[i]
diff --git a/cmd/util/doc-gen/generators/traitdocgen.go b/cmd/util/doc-gen/generators/traitdocgen.go
index 57bdd6f..e915986 100644
--- a/cmd/util/doc-gen/generators/traitdocgen.go
+++ b/cmd/util/doc-gen/generators/traitdocgen.go
@@ -55,7 +55,7 @@ const (
 
 var tagTraitID = regexp.MustCompile(fmt.Sprintf("%s=([a-z0-9-]+)", regexp.QuoteMeta(tagTrait)))
 
-// traitDocGen produces documentation about traits
+// traitDocGen produces documentation about traits.
 type traitDocGen struct {
 	generator.DefaultGen
 	arguments           *args.GeneratorArgs
@@ -241,7 +241,7 @@ func filterOutTagsAndComments(comments []string) []string {
 	return res
 }
 
-// escapeAsciiDoc is in charge to escape those chars used for formatting purposes
+// escapeAsciiDoc is in charge to escape those chars used for formatting purposes.
 func escapeASCIIDoc(text string) string {
 	return strings.ReplaceAll(text, "|", "\\|")
 }
diff --git a/cmd/util/doc-gen/generators/traitmetadatagen.go b/cmd/util/doc-gen/generators/traitmetadatagen.go
index aae0da7..c39fc7e 100644
--- a/cmd/util/doc-gen/generators/traitmetadatagen.go
+++ b/cmd/util/doc-gen/generators/traitmetadatagen.go
@@ -33,7 +33,7 @@ import (
 	"k8s.io/gengo/types"
 )
 
-// traitMetaDataGen produces YAML documentation about trait descriptions
+// traitMetaDataGen produces YAML documentation about trait descriptions.
 type traitMetaDataGen struct {
 	generator.DefaultGen
 	arguments *args.GeneratorArgs
@@ -58,7 +58,7 @@ type traitPropertyMetaData struct {
 	Description string `yaml:"description"`
 }
 
-// NewtraitMetaDataGen --
+// NewtraitMetaDataGen --.
 func NewtraitMetaDataGen(arguments *args.GeneratorArgs) generator.Generator {
 	return &traitMetaDataGen{
 		DefaultGen: generator.DefaultGen{},
diff --git a/cmd/util/vfs-gen/main.go b/cmd/util/vfs-gen/main.go
index 1fd428e..5f01ac3 100644
--- a/cmd/util/vfs-gen/main.go
+++ b/cmd/util/vfs-gen/main.go
@@ -170,7 +170,7 @@ func NamedFilesFilter(names ...string) func(path string, fi os.FileInfo) bool {
 }
 
 //
-// If file is bigger than maximum size (in bytes) then exclude
+// If file is bigger than maximum size (in bytes) then exclude.
 //
 func BigFilesFilter(size int) func(path string, fi os.FileInfo) bool {
 	return func(path string, fi os.FileInfo) bool {
@@ -230,7 +230,7 @@ func checkDir(dirName string) error {
 	return nil
 }
 
-// modTimeFS wraps http.FileSystem to set mod time to 0 for all files
+// modTimeFS wraps http.FileSystem to set mod time to 0 for all files.
 type modTimeFS struct {
 	fs http.FileSystem
 }
diff --git a/pkg/apis/apis.go b/pkg/apis/apis.go
index 38e2cc0..f701557 100644
--- a/pkg/apis/apis.go
+++ b/pkg/apis/apis.go
@@ -21,10 +21,10 @@ import (
 	"k8s.io/apimachinery/pkg/runtime"
 )
 
-// AddToSchemes may be used to add all resources defined in the project to a Scheme
+// AddToSchemes may be used to add all resources defined in the project to a Scheme.
 var AddToSchemes runtime.SchemeBuilder
 
-// AddToScheme adds all Resources to the Scheme
+// AddToScheme adds all Resources to the Scheme.
 func AddToScheme(s *runtime.Scheme) error {
 	return AddToSchemes.AddToScheme(s)
 }
diff --git a/pkg/builder/kaniko.go b/pkg/builder/kaniko.go
index a19d368..82177a7 100644
--- a/pkg/builder/kaniko.go
+++ b/pkg/builder/kaniko.go
@@ -17,5 +17,5 @@ limitations under the License.
 
 package builder
 
-// KanikoCacheDir is the cache directory for Kaniko builds (mounted into the Kaniko pod)
+// KanikoCacheDir is the cache directory for Kaniko builds (mounted into the Kaniko pod).
 const KanikoCacheDir = "/kaniko/cache"
diff --git a/pkg/builder/types.go b/pkg/builder/types.go
index 3e5d1d8..8897e11 100644
--- a/pkg/builder/types.go
+++ b/pkg/builder/types.go
@@ -28,15 +28,15 @@ import (
 )
 
 const (
-	// InitPhase --
+	// InitPhase --.
 	InitPhase int32 = 0
-	// ProjectGenerationPhase --
+	// ProjectGenerationPhase --.
 	ProjectGenerationPhase int32 = 10
-	// ProjectBuildPhase --
+	// ProjectBuildPhase --.
 	ProjectBuildPhase int32 = 20
-	// ApplicationPackagePhase --
+	// ApplicationPackagePhase --.
 	ApplicationPackagePhase int32 = 30
-	// ApplicationPublishPhase --
+	// ApplicationPublishPhase --.
 	ApplicationPublishPhase int32 = 40
 )
 
diff --git a/pkg/client/client.go b/pkg/client/client.go
index 3d34f1e..0893363 100644
--- a/pkg/client/client.go
+++ b/pkg/client/client.go
@@ -55,7 +55,7 @@ const (
 	kubeConfigEnvVar         = "KUBECONFIG"
 )
 
-// Client is an abstraction for a k8s client
+// Client is an abstraction for a k8s client.
 type Client interface {
 	controller.Client
 	kubernetes.Interface
@@ -66,12 +66,12 @@ type Client interface {
 	GetCurrentNamespace(kubeConfig string) (string, error)
 }
 
-// Injectable identifies objects that can receive a Client
+// Injectable identifies objects that can receive a Client.
 type Injectable interface {
 	InjectClient(Client)
 }
 
-// Provider is used to provide a new instance of the Client each time it's required
+// Provider is used to provide a new instance of the Client each time it's required.
 type Provider struct {
 	Get func() (Client, error)
 }
@@ -84,7 +84,7 @@ type defaultClient struct {
 	config *rest.Config
 }
 
-// Check interface compliance
+// Check interface compliance.
 var _ Client = &defaultClient{}
 
 func (c *defaultClient) CamelV1() camelv1.CamelV1Interface {
@@ -107,14 +107,14 @@ func (c *defaultClient) GetCurrentNamespace(kubeConfig string) (string, error) {
 	return GetCurrentNamespace(kubeConfig)
 }
 
-// NewOutOfClusterClient creates a new k8s client that can be used from outside the cluster
+// NewOutOfClusterClient creates a new k8s client that can be used from outside the cluster.
 func NewOutOfClusterClient(kubeconfig string) (Client, error) {
 	initialize(kubeconfig)
 	// using fast discovery from outside the cluster
 	return NewClient(true)
 }
 
-// NewClient creates a new k8s client that can be used from outside or in the cluster
+// NewClient creates a new k8s client that can be used from outside or in the cluster.
 func NewClient(fastDiscovery bool) (Client, error) {
 	// Get a config to talk to the apiserver
 	cfg, err := config.GetConfig()
@@ -163,7 +163,7 @@ func NewClient(fastDiscovery bool) (Client, error) {
 	}, nil
 }
 
-// FromManager creates a new k8s client from a manager object
+// FromManager creates a new k8s client from a manager object.
 func FromManager(manager manager.Manager) (Client, error) {
 	var err error
 	var clientset kubernetes.Interface
@@ -184,7 +184,7 @@ func FromManager(manager manager.Manager) (Client, error) {
 	}, nil
 }
 
-// init initialize the k8s client for usage outside the cluster
+// init initialize the k8s client for usage outside the cluster.
 func initialize(kubeconfig string) {
 	if kubeconfig == "" {
 		// skip out-of-cluster initialization if inside the container
@@ -214,7 +214,7 @@ func getDefaultKubeConfigFile() (string, error) {
 	return filepath.Join(dir, ".kube", "config"), nil
 }
 
-// GetCurrentNamespace --
+// GetCurrentNamespace --.
 func GetCurrentNamespace(kubeconfig string) (string, error) {
 	if kubeconfig == "" {
 		kubeContainer, err := shouldUseContainerMode()
diff --git a/pkg/cmd/bind.go b/pkg/cmd/bind.go
index 355f00d..019c1ff 100644
--- a/pkg/cmd/bind.go
+++ b/pkg/cmd/bind.go
@@ -36,7 +36,7 @@ import (
 	"sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// newCmdBind --
+// newCmdBind --.
 func newCmdBind(rootCmdOptions *RootCmdOptions) (*cobra.Command, *bindCmdOptions) {
 	options := bindCmdOptions{
 		RootCmdOptions: rootCmdOptions,
diff --git a/pkg/cmd/builder/builder.go b/pkg/cmd/builder/builder.go
index 73447c4..bd22ddf 100644
--- a/pkg/cmd/builder/builder.go
+++ b/pkg/cmd/builder/builder.go
@@ -52,7 +52,7 @@ func printVersion() {
 	log.Info(fmt.Sprintf("Camel K Version: %v", defaults.Version))
 }
 
-// Run a build resource in the specified namespace
+// Run a build resource in the specified namespace.
 func Run(namespace string, buildName string, taskName string) {
 	logf.SetLogger(zap.New(func(o *zap.Options) {
 		o.Development = false
diff --git a/pkg/cmd/delete.go b/pkg/cmd/delete.go
index fb1a6fa..2eafc57 100644
--- a/pkg/cmd/delete.go
+++ b/pkg/cmd/delete.go
@@ -33,7 +33,7 @@ import (
 	k8sclient "sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// newCmdDelete --
+// newCmdDelete --.
 func newCmdDelete(rootCmdOptions *RootCmdOptions) (*cobra.Command, *deleteCmdOptions) {
 	options := deleteCmdOptions{
 		RootCmdOptions: rootCmdOptions,
diff --git a/pkg/cmd/modeline.go b/pkg/cmd/modeline.go
index 620fe66..e32d289 100644
--- a/pkg/cmd/modeline.go
+++ b/pkg/cmd/modeline.go
@@ -50,14 +50,14 @@ var (
 		"sync": true,
 	}
 
-	// file options must be considered relative to the source files they belong to
+	// file options must be considered relative to the source files they belong to.
 	fileOptions = map[string]bool{
 		"kube-config":   true,
 		"open-api":      true,
 		"property-file": true,
 	}
 
-	// file format options are those options that admit multiple values, not only files (ie, key=value|configmap|secret|file syntax)
+	// file format options are those options that admit multiple values, not only files (ie, key=value|configmap|secret|file syntax).
 	fileFormatOptions = map[string]bool{
 		"resource":       true,
 		"config":         true,
@@ -66,7 +66,7 @@ var (
 	}
 )
 
-// NewKamelWithModelineCommand ---
+// NewKamelWithModelineCommand ---.
 func NewKamelWithModelineCommand(ctx context.Context, osArgs []string) (*cobra.Command, []string, error) {
 	originalFlags := osArgs[1:]
 	rootCmd, flags, err := createKamelWithModelineCommand(ctx, originalFlags)
diff --git a/pkg/cmd/operator/operator.go b/pkg/cmd/operator/operator.go
index a2d2040..1d140ea 100644
--- a/pkg/cmd/operator/operator.go
+++ b/pkg/cmd/operator/operator.go
@@ -72,7 +72,7 @@ func printVersion() {
 	log.Info(fmt.Sprintf("Camel K Git Commit: %v", defaults.GitCommit))
 }
 
-// Run starts the Camel K operator
+// Run starts the Camel K operator.
 func Run(healthPort, monitoringPort int32, leaderElection bool) {
 	rand.Seed(time.Now().UTC().UnixNano())
 
@@ -186,7 +186,7 @@ func Run(healthPort, monitoringPort int32, leaderElection bool) {
 	exitOnError(mgr.Start(signals.SetupSignalHandler()), "manager exited non-zero")
 }
 
-// getWatchNamespace returns the Namespace the operator should be watching for changes
+// getWatchNamespace returns the Namespace the operator should be watching for changes.
 func getWatchNamespace() (string, error) {
 	ns, found := os.LookupEnv(platform.OperatorWatchNamespaceEnvVariable)
 	if !found {
diff --git a/pkg/cmd/root.go b/pkg/cmd/root.go
index 80ec92f..ffa3714 100644
--- a/pkg/cmd/root.go
+++ b/pkg/cmd/root.go
@@ -38,7 +38,7 @@ const kamelCommandLongDescription = `Apache Camel K is a lightweight integration
 superpowers.
 `
 
-// RootCmdOptions --
+// RootCmdOptions --.
 type RootCmdOptions struct {
 	RootContext   context.Context    `mapstructure:"-"`
 	Context       context.Context    `mapstructure:"-"`
@@ -48,7 +48,7 @@ type RootCmdOptions struct {
 	Namespace     string             `mapstructure:"namespace"`
 }
 
-// NewKamelCommand --
+// NewKamelCommand --.
 func NewKamelCommand(ctx context.Context) (*cobra.Command, error) {
 	childCtx, childCancel := context.WithCancel(ctx)
 	options := RootCmdOptions{
@@ -217,7 +217,7 @@ func checkAndShowCompatibilityWarning(ctx context.Context, cmd *cobra.Command, c
 	}
 }
 
-// GetCmdClient returns the client that can be used from command line tools
+// GetCmdClient returns the client that can be used from command line tools.
 func (command *RootCmdOptions) GetCmdClient() (client.Client, error) {
 	// Get the pre-computed client
 	if command._client != nil {
@@ -228,7 +228,7 @@ func (command *RootCmdOptions) GetCmdClient() (client.Client, error) {
 	return command._client, err
 }
 
-// GetCamelCmdClient returns a client to access the Camel resources
+// GetCamelCmdClient returns a client to access the Camel resources.
 func (command *RootCmdOptions) GetCamelCmdClient() (*camelv1.CamelV1Client, error) {
 	c, err := command.GetCmdClient()
 	if err != nil {
@@ -237,7 +237,7 @@ func (command *RootCmdOptions) GetCamelCmdClient() (*camelv1.CamelV1Client, erro
 	return camelv1.NewForConfig(c.GetConfig())
 }
 
-// NewCmdClient returns a new client that can be used from command line tools
+// NewCmdClient returns a new client that can be used from command line tools.
 func (command *RootCmdOptions) NewCmdClient() (client.Client, error) {
 	return client.NewOutOfClusterClient(command.KubeConfig)
 }
diff --git a/pkg/cmd/run_help.go b/pkg/cmd/run_help.go
index 38422de..9521555 100644
--- a/pkg/cmd/run_help.go
+++ b/pkg/cmd/run_help.go
@@ -32,7 +32,7 @@ import (
 
 var invalidPaths = []string{"/etc/camel", "/deployments/dependencies"}
 
-// RunConfigOption represents a config option
+// RunConfigOption represents a config option.
 type RunConfigOption struct {
 	configType      configOptionType
 	resourceName    string
@@ -40,27 +40,27 @@ type RunConfigOption struct {
 	destinationPath string
 }
 
-// DestinationPath is the location where the resource will be stored on destination
+// DestinationPath is the location where the resource will be stored on destination.
 func (runConfigOption *RunConfigOption) DestinationPath() string {
 	return runConfigOption.destinationPath
 }
 
-// Type is the type, converted as string
+// Type is the type, converted as string.
 func (runConfigOption *RunConfigOption) Type() string {
 	return string(runConfigOption.configType)
 }
 
-// Name is the name of the resource
+// Name is the name of the resource.
 func (runConfigOption *RunConfigOption) Name() string {
 	return runConfigOption.resourceName
 }
 
-// Key is the key specified for the resource
+// Key is the key specified for the resource.
 func (runConfigOption *RunConfigOption) Key() string {
 	return runConfigOption.resourceKey
 }
 
-// Validate checks if the DestinationPath is correctly configured
+// Validate checks if the DestinationPath is correctly configured.
 func (runConfigOption *RunConfigOption) Validate() error {
 	if runConfigOption.destinationPath == "" {
 		return nil
@@ -78,11 +78,11 @@ func (runConfigOption *RunConfigOption) Validate() error {
 type configOptionType string
 
 const (
-	// ConfigOptionTypeConfigmap --
+	// ConfigOptionTypeConfigmap --.
 	ConfigOptionTypeConfigmap configOptionType = "configmap"
-	// ConfigOptionTypeSecret --
+	// ConfigOptionTypeSecret --.
 	ConfigOptionTypeSecret configOptionType = "secret"
-	// ConfigOptionTypeFile --
+	// ConfigOptionTypeFile --.
 	ConfigOptionTypeFile configOptionType = "file"
 )
 
@@ -130,7 +130,7 @@ func parseCMOrSecretValue(value string) (resource string, maybeKey string, maybe
 	return groups[1], groups[3], groups[5]
 }
 
-// ParseResourceOption will parse and return a runConfigOption
+// ParseResourceOption will parse and return a runConfigOption.
 func ParseResourceOption(item string) (*RunConfigOption, error) {
 	// Deprecated: ensure backward compatibility with `--resource filename` format until version 1.5.x
 	// then replace with parseOption() func directly
@@ -146,7 +146,7 @@ func ParseResourceOption(item string) (*RunConfigOption, error) {
 	return option, nil
 }
 
-// ParseConfigOption will parse and return a runConfigOption
+// ParseConfigOption will parse and return a runConfigOption.
 func ParseConfigOption(item string) (*RunConfigOption, error) {
 	return parseOption(item)
 }
@@ -230,7 +230,7 @@ func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 	return nil
 }
 
-// ApplyConfigOption will set the proper --config option behavior to the IntegrationSpec
+// ApplyConfigOption will set the proper --config option behavior to the IntegrationSpec.
 func ApplyConfigOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
 	// A config option cannot specify destination path
 	if config.DestinationPath() != "" {
@@ -239,7 +239,7 @@ func ApplyConfigOption(config *RunConfigOption, integrationSpec *v1.IntegrationS
 	return applyOption(config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeConfig)
 }
 
-// ApplyResourceOption will set the proper --resource option behavior to the IntegrationSpec
+// ApplyResourceOption will set the proper --resource option behavior to the IntegrationSpec.
 func ApplyResourceOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec, c client.Client, namespace string, enableCompression bool) error {
 	return applyOption(config, integrationSpec, c, namespace, enableCompression, v1.ResourceTypeData)
 }
@@ -307,7 +307,7 @@ func mergePropertiesWithPrecedence(items []string) (*properties.Properties, erro
 }
 
 // The function parse the value and if it is a file (file:/path/), it will parse as property file
-// otherwise return a single property built from the item passed as `key=value`
+// otherwise return a single property built from the item passed as `key=value`.
 func extractProperties(value string) (*properties.Properties, error) {
 	if !strings.HasPrefix(value, "file:") {
 		return keyValueProps(value)
diff --git a/pkg/cmd/util.go b/pkg/cmd/util.go
index d8975cb..09768c8 100644
--- a/pkg/cmd/util.go
+++ b/pkg/cmd/util.go
@@ -45,14 +45,14 @@ import (
 const (
 	offlineCommandLabel = "camel.apache.org/cmd.offline"
 
-	// Supported source schemes
+	// Supported source schemes.
 	gistScheme   = "gist"
 	githubScheme = "github"
 	httpScheme   = "http"
 	httpsScheme  = "https"
 )
 
-// DeleteIntegration --
+// DeleteIntegration --.
 func DeleteIntegration(ctx context.Context, c client.Client, name string, namespace string) error {
 	integration := v1.Integration{
 		TypeMeta: metav1.TypeMeta{
diff --git a/pkg/cmd/util_commands.go b/pkg/cmd/util_commands.go
index 7b2bd36..c7c3605 100644
--- a/pkg/cmd/util_commands.go
+++ b/pkg/cmd/util_commands.go
@@ -100,7 +100,7 @@ func assembleIntegrationRunCommand(ctx context.Context, properties []string, dep
 	return cmd, nil
 }
 
-// RunLocalIntegrationRunCommand --
+// RunLocalIntegrationRunCommand --.
 func RunLocalIntegrationRunCommand(ctx context.Context, properties []string, dependencies []string, routes []string, propertiesDir string, stdout, stderr io.Writer) error {
 	cmd, err := assembleIntegrationRunCommand(ctx, properties, dependencies, routes, propertiesDir, stdout, stderr, true)
 	if err != nil {
@@ -119,7 +119,7 @@ func RunLocalIntegrationRunCommand(ctx context.Context, properties []string, dep
 	return nil
 }
 
-// GetContainerIntegrationRunCommand --
+// GetContainerIntegrationRunCommand --.
 func GetContainerIntegrationRunCommand(ctx context.Context, properties []string, dependencies []string, routes []string, stdout, stderr io.Writer) (*exec.Cmd, error) {
 	// This is the integration command which will be run inside the container. Therefore all paths need to
 	// be valid container paths.
diff --git a/pkg/cmd/util_config.go b/pkg/cmd/util_config.go
index 9c4239e..68d47eb 100644
--- a/pkg/cmd/util_config.go
+++ b/pkg/cmd/util_config.go
@@ -34,26 +34,26 @@ import (
 )
 
 const (
-	// DefaultConfigName is the default config name
+	// DefaultConfigName is the default config name.
 	DefaultConfigName = "kamel-config"
 
-	// DefaultConfigLocation is the main place where the kamel content is stored
+	// DefaultConfigLocation is the main place where the kamel content is stored.
 	DefaultConfigLocation = DefaultConfigName + ".yaml"
 
-	// KamelTagName ---
+	// KamelTagName ---.
 	KamelTagName = "kamel"
 
-	// MapstructureTagName ---
+	// MapstructureTagName ---.
 	MapstructureTagName = "mapstructure"
 )
 
-// Config is a helper class to manipulate kamel configuration files
+// Config is a helper class to manipulate kamel configuration files.
 type Config struct {
 	location string
 	content  map[string]interface{}
 }
 
-// LoadConfiguration loads a kamel configuration file
+// LoadConfiguration loads a kamel configuration file.
 func LoadConfiguration() (*Config, error) {
 	config := Config{
 		location: viper.ConfigFileUsed(),
@@ -81,7 +81,7 @@ func LoadConfiguration() (*Config, error) {
 	return &config, nil
 }
 
-// Update ---
+// Update ---.
 func (cfg *Config) Update(cmd *cobra.Command, nodeID string, data interface{}, changedOnly bool) {
 	values := make(map[string]interface{})
 
@@ -117,7 +117,7 @@ func (cfg *Config) Update(cmd *cobra.Command, nodeID string, data interface{}, c
 	}
 }
 
-// SetNode allows to replace a subtree with a given content
+// SetNode allows to replace a subtree with a given content.
 func (cfg *Config) SetNode(nodeID string, nodeValues map[string]interface{}) {
 	cfg.Delete(nodeID)
 	node := cfg.navigate(cfg.content, nodeID, true)
@@ -127,7 +127,7 @@ func (cfg *Config) SetNode(nodeID string, nodeValues map[string]interface{}) {
 	}
 }
 
-// Delete allows to remove a sub tree from the kamel content
+// Delete allows to remove a sub tree from the kamel content.
 func (cfg *Config) Delete(path string) {
 	leaf := cfg.navigate(cfg.content, path, false)
 	for k := range leaf {
@@ -135,7 +135,7 @@ func (cfg *Config) Delete(path string) {
 	}
 }
 
-// Save ---
+// Save ---.
 func (cfg *Config) Save() error {
 	root := filepath.Dir(cfg.location)
 	if _, err := os.Stat(root); os.IsNotExist(err) {
diff --git a/pkg/cmd/util_sources.go b/pkg/cmd/util_sources.go
index 4765535..2ab6d76 100644
--- a/pkg/cmd/util_sources.go
+++ b/pkg/cmd/util_sources.go
@@ -34,7 +34,7 @@ import (
 	"github.com/pkg/errors"
 )
 
-// Source ---
+// Source ---.
 type Source struct {
 	Origin   string
 	Location string
@@ -59,7 +59,7 @@ func (s *Source) setContent(content []byte) error {
 	return nil
 }
 
-// ResolveSources ---
+// ResolveSources ---.
 func ResolveSources(ctx context.Context, locations []string, compress bool) ([]Source, error) {
 	sources := make([]Source, 0, len(locations))
 
@@ -189,7 +189,7 @@ func ResolveSources(ctx context.Context, locations []string, compress bool) ([]S
 	return sources, nil
 }
 
-// ResolveLocalSource --
+// ResolveLocalSource --.
 func ResolveLocalSource(location string, compress bool) (Source, error) {
 	if _, err := os.Stat(location); err != nil && os.IsNotExist(err) {
 		return Source{}, errors.Wrapf(err, "file %s does not exist", location)
diff --git a/pkg/cmd/version.go b/pkg/cmd/version.go
index 0f8eb0a..02993dd 100644
--- a/pkg/cmd/version.go
+++ b/pkg/cmd/version.go
@@ -33,7 +33,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/defaults"
 )
 
-// VersionVariant may be overridden at build time
+// VersionVariant may be overridden at build time.
 var VersionVariant = ""
 
 const (
diff --git a/pkg/controller/build/action.go b/pkg/controller/build/action.go
index 6882afe..4fab3a3 100644
--- a/pkg/controller/build/action.go
+++ b/pkg/controller/build/action.go
@@ -28,7 +28,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/build/build_controller.go b/pkg/controller/build/build_controller.go
index cfafba3..0bb9d12 100644
--- a/pkg/controller/build/build_controller.go
+++ b/pkg/controller/build/build_controller.go
@@ -92,7 +92,7 @@ func add(mgr manager.Manager, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &reconcileBuild{}
 
-// reconcileBuild reconciles a Build object
+// reconcileBuild reconciles a Build object.
 type reconcileBuild struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/build/error.go b/pkg/controller/build/error.go
index 7bdd859..c228647 100644
--- a/pkg/controller/build/error.go
+++ b/pkg/controller/build/error.go
@@ -31,17 +31,17 @@ type errorAction struct {
 	baseAction
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *errorAction) Name() string {
 	return "error"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *errorAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == v1.BuildPhaseError
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *errorAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	return nil, nil
 }
diff --git a/pkg/controller/build/initialize_pod.go b/pkg/controller/build/initialize_pod.go
index e911c64..41ded20 100644
--- a/pkg/controller/build/initialize_pod.go
+++ b/pkg/controller/build/initialize_pod.go
@@ -38,17 +38,17 @@ type initializePodAction struct {
 	reader ctrl.Reader
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *initializePodAction) Name() string {
 	return "initialize-pod"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *initializePodAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == "" || build.Status.Phase == v1.BuildPhaseInitialization
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *initializePodAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	if err := deleteBuilderPod(ctx, action.client, build); err != nil {
 		return nil, errors.Wrap(err, "cannot delete build pod")
diff --git a/pkg/controller/build/initialize_routine.go b/pkg/controller/build/initialize_routine.go
index f621da5..1977c49 100644
--- a/pkg/controller/build/initialize_routine.go
+++ b/pkg/controller/build/initialize_routine.go
@@ -31,17 +31,17 @@ type initializeRoutineAction struct {
 	baseAction
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *initializeRoutineAction) Name() string {
 	return "initialize"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *initializeRoutineAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == "" || build.Status.Phase == v1.BuildPhaseInitialization
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *initializeRoutineAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	build.Status.Phase = v1.BuildPhaseScheduling
 
diff --git a/pkg/controller/build/log.go b/pkg/controller/build/log.go
index 0bf176a..30e23d3 100644
--- a/pkg/controller/build/log.go
+++ b/pkg/controller/build/log.go
@@ -19,5 +19,5 @@ package build
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("build")
diff --git a/pkg/controller/build/monitor_pod.go b/pkg/controller/build/monitor_pod.go
index 71c7ed9..960fd6f 100644
--- a/pkg/controller/build/monitor_pod.go
+++ b/pkg/controller/build/monitor_pod.go
@@ -50,17 +50,17 @@ type monitorPodAction struct {
 	reader ctrl.Reader
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *monitorPodAction) Name() string {
 	return "monitor-pod"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *monitorPodAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == v1.BuildPhasePending || build.Status.Phase == v1.BuildPhaseRunning
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *monitorPodAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	pod, err := getBuilderPod(ctx, action.reader, build)
 	if err != nil {
diff --git a/pkg/controller/build/monitor_routine.go b/pkg/controller/build/monitor_routine.go
index cea4d0b..f9d0083 100644
--- a/pkg/controller/build/monitor_routine.go
+++ b/pkg/controller/build/monitor_routine.go
@@ -47,17 +47,17 @@ type monitorRoutineAction struct {
 	baseAction
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *monitorRoutineAction) Name() string {
 	return "monitor-routine"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *monitorRoutineAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == v1.BuildPhasePending || build.Status.Phase == v1.BuildPhaseRunning
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *monitorRoutineAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	switch build.Status.Phase {
 
diff --git a/pkg/controller/build/schedule.go b/pkg/controller/build/schedule.go
index 28a2756..6f9e4bd 100644
--- a/pkg/controller/build/schedule.go
+++ b/pkg/controller/build/schedule.go
@@ -43,17 +43,17 @@ type scheduleAction struct {
 	reader ctrl.Reader
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *scheduleAction) Name() string {
 	return "schedule"
 }
 
-// CanHandle tells whether this action can handle the build
+// CanHandle tells whether this action can handle the build.
 func (action *scheduleAction) CanHandle(build *v1.Build) bool {
 	return build.Status.Phase == v1.BuildPhaseScheduling
 }
 
-// Handle handles the builds
+// Handle handles the builds.
 func (action *scheduleAction) Handle(ctx context.Context, build *v1.Build) (*v1.Build, error) {
 	// Enter critical section
 	action.lock.Lock()
diff --git a/pkg/controller/controller.go b/pkg/controller/controller.go
index beb518c..6ce6199 100644
--- a/pkg/controller/controller.go
+++ b/pkg/controller/controller.go
@@ -20,10 +20,10 @@ import (
 	"sigs.k8s.io/controller-runtime/pkg/manager"
 )
 
-// AddToManagerFuncs is a list of functions to add all Controllers to the Manager
+// AddToManagerFuncs is a list of functions to add all Controllers to the Manager.
 var AddToManagerFuncs []func(manager.Manager) error
 
-// AddToManager adds all Controllers to the Manager
+// AddToManager adds all Controllers to the Manager.
 func AddToManager(m manager.Manager) error {
 	for _, f := range AddToManagerFuncs {
 		if err := f(m); err != nil {
diff --git a/pkg/controller/integration/action.go b/pkg/controller/integration/action.go
index 3b5c5a2..e56011c 100644
--- a/pkg/controller/integration/action.go
+++ b/pkg/controller/integration/action.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/integration/initialize.go b/pkg/controller/integration/initialize.go
index 3eecb09..e05e614 100644
--- a/pkg/controller/integration/initialize.go
+++ b/pkg/controller/integration/initialize.go
@@ -30,7 +30,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/defaults"
 )
 
-// NewInitializeAction creates a new initialize action
+// NewInitializeAction creates a new initialize action.
 func NewInitializeAction() Action {
 	return &initializeAction{}
 }
@@ -39,17 +39,17 @@ type initializeAction struct {
 	baseAction
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *initializeAction) Name() string {
 	return "initialize"
 }
 
-// CanHandle tells whether this action can handle the integration
+// CanHandle tells whether this action can handle the integration.
 func (action *initializeAction) CanHandle(integration *v1.Integration) bool {
 	return integration.Status.Phase == v1.IntegrationPhaseInitialization
 }
 
-// Handle handles the integrations
+// Handle handles the integrations.
 func (action *initializeAction) Handle(ctx context.Context, integration *v1.Integration) (*v1.Integration, error) {
 	if _, err := trait.Apply(ctx, action.client, integration, nil); err != nil {
 		return nil, err
diff --git a/pkg/controller/integration/integration_controller.go b/pkg/controller/integration/integration_controller.go
index 342db8c..bc65c06 100644
--- a/pkg/controller/integration/integration_controller.go
+++ b/pkg/controller/integration/integration_controller.go
@@ -243,7 +243,7 @@ func add(mgr manager.Manager, c client.Client, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &reconcileIntegration{}
 
-// reconcileIntegration reconciles an Integration object
+// reconcileIntegration reconciles an Integration object.
 type reconcileIntegration struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/integration/kits.go b/pkg/controller/integration/kits.go
index f31fabf..6994ab2 100644
--- a/pkg/controller/integration/kits.go
+++ b/pkg/controller/integration/kits.go
@@ -81,7 +81,7 @@ func lookupKitsForIntegration(ctx context.Context, c ctrl.Reader, integration *v
 	return kits, nil
 }
 
-// integrationMatches returns whether the v1.IntegrationKit meets the requirements of the v1.Integration
+// integrationMatches returns whether the v1.IntegrationKit meets the requirements of the v1.Integration.
 func integrationMatches(integration *v1.Integration, kit *v1.IntegrationKit) (bool, error) {
 	if kit.Status.Phase == v1.IntegrationKitPhaseError {
 		return false, nil
@@ -117,7 +117,7 @@ func integrationMatches(integration *v1.Integration, kit *v1.IntegrationKit) (bo
 	return true, nil
 }
 
-// kitMatches returns whether the two v1.IntegrationKit match
+// kitMatches returns whether the two v1.IntegrationKit match.
 func kitMatches(kit1 *v1.IntegrationKit, kit2 *v1.IntegrationKit) (bool, error) {
 	version := kit1.Status.Version
 	if version == "" {
@@ -235,7 +235,7 @@ func hasMatchingTrait(ts1 *v1.TraitSpec, ts2 *v1.TraitSpec) (bool, error) {
 	return true, nil
 }
 
-// We need to try to perform a slice equality in order to prevent a runtime panic
+// We need to try to perform a slice equality in order to prevent a runtime panic.
 func equal(a, b interface{}) bool {
 	aSlice, aOk := a.([]interface{})
 	bSlice, bOk := b.([]interface{})
diff --git a/pkg/controller/integration/log.go b/pkg/controller/integration/log.go
index 621d233..5a828c3 100644
--- a/pkg/controller/integration/log.go
+++ b/pkg/controller/integration/log.go
@@ -19,5 +19,5 @@ package integration
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("integration")
diff --git a/pkg/controller/integration/monitor.go b/pkg/controller/integration/monitor.go
index 492cb97..e0877e7 100644
--- a/pkg/controller/integration/monitor.go
+++ b/pkg/controller/integration/monitor.go
@@ -44,7 +44,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/kubernetes"
 )
 
-// The key used for propagating error details from Camel health to MicroProfile Health (See CAMEL-17138)
+// The key used for propagating error details from Camel health to MicroProfile Health (See CAMEL-17138).
 const runtimeHealthCheckErrorMessage = "error.message"
 
 func NewMonitorAction() Action {
diff --git a/pkg/controller/integration/platform_setup.go b/pkg/controller/integration/platform_setup.go
index 8d01324..148673e 100644
--- a/pkg/controller/integration/platform_setup.go
+++ b/pkg/controller/integration/platform_setup.go
@@ -29,7 +29,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/knative"
 )
 
-// NewPlatformSetupAction creates a new platform-setup action
+// NewPlatformSetupAction creates a new platform-setup action.
 func NewPlatformSetupAction() Action {
 	return &platformSetupAction{}
 }
@@ -38,18 +38,18 @@ type platformSetupAction struct {
 	baseAction
 }
 
-// Name returns a common name of the action
+// Name returns a common name of the action.
 func (action *platformSetupAction) Name() string {
 	return "platform-setup"
 }
 
-// CanHandle tells whether this action can handle the integration
+// CanHandle tells whether this action can handle the integration.
 func (action *platformSetupAction) CanHandle(integration *v1.Integration) bool {
 	return integration.Status.Phase == v1.IntegrationPhaseNone ||
 		integration.Status.Phase == v1.IntegrationPhaseWaitingForPlatform
 }
 
-// Handle handles the integrations
+// Handle handles the integrations.
 func (action *platformSetupAction) Handle(ctx context.Context, integration *v1.Integration) (*v1.Integration, error) {
 	if _, err := trait.Apply(ctx, action.client, integration, nil); err != nil {
 		return nil, err
@@ -65,7 +65,7 @@ func (action *platformSetupAction) Handle(ctx context.Context, integration *v1.I
 	return integration, nil
 }
 
-// DetermineBestProfile tries to detect the best trait profile for the integration
+// DetermineBestProfile tries to detect the best trait profile for the integration.
 func determineBestProfile(ctx context.Context, c client.Client, integration *v1.Integration, p *v1.IntegrationPlatform) v1.TraitProfile {
 	if integration.Spec.Profile != "" {
 		return integration.Spec.Profile
diff --git a/pkg/controller/integrationkit/action.go b/pkg/controller/integrationkit/action.go
index 843d303..980cdf7 100644
--- a/pkg/controller/integrationkit/action.go
+++ b/pkg/controller/integrationkit/action.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/integrationkit/build.go b/pkg/controller/integrationkit/build.go
index ea91f6f..9ea226f 100644
--- a/pkg/controller/integrationkit/build.go
+++ b/pkg/controller/integrationkit/build.go
@@ -36,7 +36,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/kubernetes"
 )
 
-// NewBuildAction creates a new build request handling action for the kit
+// NewBuildAction creates a new build request handling action for the kit.
 func NewBuildAction() Action {
 	return &buildAction{}
 }
diff --git a/pkg/controller/integrationkit/error.go b/pkg/controller/integrationkit/error.go
index ec22114..59ac2df 100644
--- a/pkg/controller/integrationkit/error.go
+++ b/pkg/controller/integrationkit/error.go
@@ -24,7 +24,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/digest"
 )
 
-// NewErrorAction creates a new error handling action for the kit
+// NewErrorAction creates a new error handling action for the kit.
 func NewErrorAction() Action {
 	return &errorAction{}
 }
diff --git a/pkg/controller/integrationkit/initialize.go b/pkg/controller/integrationkit/initialize.go
index 0ecde6b..b0c7978 100644
--- a/pkg/controller/integrationkit/initialize.go
+++ b/pkg/controller/integrationkit/initialize.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/defaults"
 )
 
-// NewInitializeAction creates a new initialization handling action for the kit
+// NewInitializeAction creates a new initialization handling action for the kit.
 func NewInitializeAction() Action {
 	return &initializeAction{}
 }
diff --git a/pkg/controller/integrationkit/integrationkit_controller.go b/pkg/controller/integrationkit/integrationkit_controller.go
index 3e7b22f..35176cf 100644
--- a/pkg/controller/integrationkit/integrationkit_controller.go
+++ b/pkg/controller/integrationkit/integrationkit_controller.go
@@ -54,7 +54,7 @@ func Add(mgr manager.Manager) error {
 	return add(mgr, newReconciler(mgr, c))
 }
 
-// newReconciler returns a new reconcile.Reconciler
+// newReconciler returns a new reconcile.Reconciler.
 func newReconciler(mgr manager.Manager, c client.Client) reconcile.Reconciler {
 	return monitoring.NewInstrumentedReconciler(
 		&reconcileIntegrationKit{
@@ -70,7 +70,7 @@ func newReconciler(mgr manager.Manager, c client.Client) reconcile.Reconciler {
 	)
 }
 
-// add adds a new Controller to mgr with r as the reconcile.Reconciler
+// add adds a new Controller to mgr with r as the reconcile.Reconciler.
 func add(mgr manager.Manager, r reconcile.Reconciler) error {
 	// Create a new controller
 	c, err := controller.New("integrationkit-controller", mgr, controller.Options{Reconciler: r})
@@ -178,7 +178,7 @@ func add(mgr manager.Manager, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &reconcileIntegrationKit{}
 
-// reconcileIntegrationKit reconciles a IntegrationKit object
+// reconcileIntegrationKit reconciles a IntegrationKit object.
 type reconcileIntegrationKit struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/integrationkit/log.go b/pkg/controller/integrationkit/log.go
index 7743369..043dd85 100644
--- a/pkg/controller/integrationkit/log.go
+++ b/pkg/controller/integrationkit/log.go
@@ -19,5 +19,5 @@ package integrationkit
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("integrationkit")
diff --git a/pkg/controller/integrationkit/monitor.go b/pkg/controller/integrationkit/monitor.go
index 336a574..8e4b2be 100644
--- a/pkg/controller/integrationkit/monitor.go
+++ b/pkg/controller/integrationkit/monitor.go
@@ -24,7 +24,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/digest"
 )
 
-// NewMonitorAction creates a new monitoring handling action for the kit
+// NewMonitorAction creates a new monitoring handling action for the kit.
 func NewMonitorAction() Action {
 	return &monitorAction{}
 }
diff --git a/pkg/controller/integrationplatform/action.go b/pkg/controller/integrationplatform/action.go
index 3fe2f6d..4671dcb 100644
--- a/pkg/controller/integrationplatform/action.go
+++ b/pkg/controller/integrationplatform/action.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/integrationplatform/create.go b/pkg/controller/integrationplatform/create.go
index 7e075fe..aabf9b4 100644
--- a/pkg/controller/integrationplatform/create.go
+++ b/pkg/controller/integrationplatform/create.go
@@ -28,7 +28,7 @@ import (
 	"github.com/apache/camel-k/pkg/install"
 )
 
-// NewCreateAction returns a action that creates resources needed by the platform
+// NewCreateAction returns a action that creates resources needed by the platform.
 func NewCreateAction() Action {
 	return &createAction{}
 }
diff --git a/pkg/controller/integrationplatform/initialize.go b/pkg/controller/integrationplatform/initialize.go
index eea1a50..6bb5b3b 100644
--- a/pkg/controller/integrationplatform/initialize.go
+++ b/pkg/controller/integrationplatform/initialize.go
@@ -31,7 +31,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/defaults"
 )
 
-// NewInitializeAction returns a action that initializes the platform configuration when not provided by the user
+// NewInitializeAction returns a action that initializes the platform configuration when not provided by the user.
 func NewInitializeAction() Action {
 	return &initializeAction{}
 }
diff --git a/pkg/controller/integrationplatform/integrationplatform_controller.go b/pkg/controller/integrationplatform/integrationplatform_controller.go
index 5f25ee6..fbf3b66 100644
--- a/pkg/controller/integrationplatform/integrationplatform_controller.go
+++ b/pkg/controller/integrationplatform/integrationplatform_controller.go
@@ -51,7 +51,7 @@ func Add(mgr manager.Manager) error {
 	return add(mgr, newReconciler(mgr, c))
 }
 
-// newReconciler returns a new reconcile.Reconciler
+// newReconciler returns a new reconcile.Reconciler.
 func newReconciler(mgr manager.Manager, c client.Client) reconcile.Reconciler {
 	return monitoring.NewInstrumentedReconciler(
 		&reconcileIntegrationPlatform{
@@ -68,7 +68,7 @@ func newReconciler(mgr manager.Manager, c client.Client) reconcile.Reconciler {
 	)
 }
 
-// add adds a new Controller to mgr with r as the reconcile.Reconciler
+// add adds a new Controller to mgr with r as the reconcile.Reconciler.
 func add(mgr manager.Manager, r reconcile.Reconciler) error {
 	// Create a new controller
 	c, err := controller.New("integrationplatform-controller", mgr, controller.Options{Reconciler: r})
@@ -110,7 +110,7 @@ func add(mgr manager.Manager, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &reconcileIntegrationPlatform{}
 
-// reconcileIntegrationPlatform reconciles a IntegrationPlatform object
+// reconcileIntegrationPlatform reconciles a IntegrationPlatform object.
 type reconcileIntegrationPlatform struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/integrationplatform/log.go b/pkg/controller/integrationplatform/log.go
index 8640d08..1a44b85 100644
--- a/pkg/controller/integrationplatform/log.go
+++ b/pkg/controller/integrationplatform/log.go
@@ -19,5 +19,5 @@ package integrationplatform
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("integrationplatform")
diff --git a/pkg/controller/integrationplatform/monitor.go b/pkg/controller/integrationplatform/monitor.go
index d8968fc..e2c7d0c 100644
--- a/pkg/controller/integrationplatform/monitor.go
+++ b/pkg/controller/integrationplatform/monitor.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/defaults"
 )
 
-// NewMonitorAction returns an action that monitors the integration platform after it's fully initialized
+// NewMonitorAction returns an action that monitors the integration platform after it's fully initialized.
 func NewMonitorAction() Action {
 	return &monitorAction{}
 }
diff --git a/pkg/controller/kamelet/action.go b/pkg/controller/kamelet/action.go
index 7f07717..f0a7120 100644
--- a/pkg/controller/kamelet/action.go
+++ b/pkg/controller/kamelet/action.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/kamelet/initialize.go b/pkg/controller/kamelet/initialize.go
index f1bbc1e..a262a18 100644
--- a/pkg/controller/kamelet/initialize.go
+++ b/pkg/controller/kamelet/initialize.go
@@ -24,7 +24,7 @@ import (
 	kameletutils "github.com/apache/camel-k/pkg/kamelet"
 )
 
-// NewInitializeAction returns a action that initializes the kamelet configuration when not provided by the user
+// NewInitializeAction returns a action that initializes the kamelet configuration when not provided by the user.
 func NewInitializeAction() Action {
 	return &initializeAction{}
 }
diff --git a/pkg/controller/kamelet/kamelet_controller.go b/pkg/controller/kamelet/kamelet_controller.go
index ad0f8ef..db11e05 100644
--- a/pkg/controller/kamelet/kamelet_controller.go
+++ b/pkg/controller/kamelet/kamelet_controller.go
@@ -100,7 +100,7 @@ func add(mgr manager.Manager, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &reconcileKamelet{}
 
-// reconcileKamelet reconciles a Kamelet object
+// reconcileKamelet reconciles a Kamelet object.
 type reconcileKamelet struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/kamelet/log.go b/pkg/controller/kamelet/log.go
index 2df12a4..3a734fb 100644
--- a/pkg/controller/kamelet/log.go
+++ b/pkg/controller/kamelet/log.go
@@ -19,5 +19,5 @@ package kamelet
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("kamelet")
diff --git a/pkg/controller/kamelet/monitor.go b/pkg/controller/kamelet/monitor.go
index 8d90029..a11f5fa 100644
--- a/pkg/controller/kamelet/monitor.go
+++ b/pkg/controller/kamelet/monitor.go
@@ -24,7 +24,7 @@ import (
 	kameletutils "github.com/apache/camel-k/pkg/kamelet"
 )
 
-// NewMonitorAction returns an action that monitors the kamelet after it's fully initialized
+// NewMonitorAction returns an action that monitors the kamelet after it's fully initialized.
 func NewMonitorAction() Action {
 	return &monitorAction{}
 }
diff --git a/pkg/controller/kameletbinding/action.go b/pkg/controller/kameletbinding/action.go
index b0688c0..88c120c 100644
--- a/pkg/controller/kameletbinding/action.go
+++ b/pkg/controller/kameletbinding/action.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Action --
+// Action --.
 type Action interface {
 	client.Injectable
 	log.Injectable
diff --git a/pkg/controller/kameletbinding/initialize.go b/pkg/controller/kameletbinding/initialize.go
index 66fc329..c257825 100644
--- a/pkg/controller/kameletbinding/initialize.go
+++ b/pkg/controller/kameletbinding/initialize.go
@@ -32,7 +32,7 @@ import (
 	"sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// NewInitializeAction returns a action that initializes the kamelet binding configuration when not provided by the user
+// NewInitializeAction returns a action that initializes the kamelet binding configuration when not provided by the user.
 func NewInitializeAction() Action {
 	return &initializeAction{}
 }
diff --git a/pkg/controller/kameletbinding/kamelet_binding_controller.go b/pkg/controller/kameletbinding/kamelet_binding_controller.go
index d59dc2e..c422286 100644
--- a/pkg/controller/kameletbinding/kamelet_binding_controller.go
+++ b/pkg/controller/kameletbinding/kamelet_binding_controller.go
@@ -117,7 +117,7 @@ func add(mgr manager.Manager, r reconcile.Reconciler) error {
 
 var _ reconcile.Reconciler = &ReconcileKameletBinding{}
 
-// ReconcileKameletBinding reconciles a KameletBinding object
+// ReconcileKameletBinding reconciles a KameletBinding object.
 type ReconcileKameletBinding struct {
 	// This client, initialized using mgr.Client() above, is a split client
 	// that reads objects from the cache and writes to the API server
diff --git a/pkg/controller/kameletbinding/log.go b/pkg/controller/kameletbinding/log.go
index 0162b6d..72a1a60 100644
--- a/pkg/controller/kameletbinding/log.go
+++ b/pkg/controller/kameletbinding/log.go
@@ -19,5 +19,5 @@ package kameletbinding
 
 import "github.com/apache/camel-k/pkg/util/log"
 
-// Log --
+// Log --.
 var Log = log.Log.WithName("controller").WithName("kameletbinding")
diff --git a/pkg/controller/kameletbinding/monitor.go b/pkg/controller/kameletbinding/monitor.go
index 29dd931..dcba3b2 100644
--- a/pkg/controller/kameletbinding/monitor.go
+++ b/pkg/controller/kameletbinding/monitor.go
@@ -29,7 +29,7 @@ import (
 	"sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// NewMonitorAction returns an action that monitors the kamelet binding after it's fully initialized
+// NewMonitorAction returns an action that monitors the kamelet binding after it's fully initialized.
 func NewMonitorAction() Action {
 	return &monitorAction{}
 }
diff --git a/pkg/event/manager.go b/pkg/event/manager.go
index 0f03c5b..e9629f3 100644
--- a/pkg/event/manager.go
+++ b/pkg/event/manager.go
@@ -35,53 +35,53 @@ import (
 )
 
 const (
-	// ReasonIntegrationPhaseUpdated --
+	// ReasonIntegrationPhaseUpdated --.
 	ReasonIntegrationPhaseUpdated = "IntegrationPhaseUpdated"
-	// ReasonIntegrationConditionChanged --
+	// ReasonIntegrationConditionChanged --.
 	ReasonIntegrationConditionChanged = "IntegrationConditionChanged"
-	// ReasonIntegrationError --
+	// ReasonIntegrationError --.
 	ReasonIntegrationError = "IntegrationError"
 
-	// ReasonIntegrationKitPhaseUpdated --
+	// ReasonIntegrationKitPhaseUpdated --.
 	ReasonIntegrationKitPhaseUpdated = "IntegrationKitPhaseUpdated"
-	// ReasonIntegrationKitConditionChanged --
+	// ReasonIntegrationKitConditionChanged --.
 	ReasonIntegrationKitConditionChanged = "IntegrationKitConditionChanged"
-	// ReasonIntegrationKitError --
+	// ReasonIntegrationKitError --.
 	ReasonIntegrationKitError = "IntegrationKitError"
 
-	// ReasonIntegrationPlatformPhaseUpdated --
+	// ReasonIntegrationPlatformPhaseUpdated --.
 	ReasonIntegrationPlatformPhaseUpdated = "IntegrationPlatformPhaseUpdated"
-	// ReasonIntegrationPlatformConditionChanged --
+	// ReasonIntegrationPlatformConditionChanged --.
 	ReasonIntegrationPlatformConditionChanged = "IntegrationPlatformConditionChanged"
-	// ReasonIntegrationPlatformError --
+	// ReasonIntegrationPlatformError --.
 	ReasonIntegrationPlatformError = "IntegrationPlatformError"
 
-	// ReasonBuildPhaseUpdated --
+	// ReasonBuildPhaseUpdated --.
 	ReasonBuildPhaseUpdated = "BuildPhaseUpdated"
-	// ReasonBuildConditionChanged --
+	// ReasonBuildConditionChanged --.
 	ReasonBuildConditionChanged = "BuildConditionChanged"
-	// ReasonBuildError --
+	// ReasonBuildError --.
 	ReasonBuildError = "BuildError"
 
-	// ReasonKameletError --
+	// ReasonKameletError --.
 	ReasonKameletError = "KameletError"
-	// ReasonKameletConditionChanged --
+	// ReasonKameletConditionChanged --.
 	ReasonKameletConditionChanged = "KameletConditionChanged"
-	// ReasonKameletPhaseUpdated --
+	// ReasonKameletPhaseUpdated --.
 	ReasonKameletPhaseUpdated = "KameletPhaseUpdated"
 
-	// ReasonKameletBindingError --
+	// ReasonKameletBindingError --.
 	ReasonKameletBindingError = "KameletBindingError"
-	// ReasonKameletBindingConditionChanged --
+	// ReasonKameletBindingConditionChanged --.
 	ReasonKameletBindingConditionChanged = "KameletBindingConditionChanged"
-	// ReasonKameletBindingPhaseUpdated --
+	// ReasonKameletBindingPhaseUpdated --.
 	ReasonKameletBindingPhaseUpdated = "KameletBindingPhaseUpdated"
 
-	// ReasonRelatedObjectChanged --
+	// ReasonRelatedObjectChanged --.
 	ReasonRelatedObjectChanged = "ReasonRelatedObjectChanged"
 )
 
-// NotifyIntegrationError automatically generates error events when the integration reconcile cycle phase has an error
+// NotifyIntegrationError automatically generates error events when the integration reconcile cycle phase has an error.
 func NotifyIntegrationError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.Integration, err error) {
 	it := old
 	if newResource != nil {
@@ -93,7 +93,7 @@ func NotifyIntegrationError(ctx context.Context, c client.Client, recorder recor
 	recorder.Eventf(it, corev1.EventTypeWarning, ReasonIntegrationError, "Cannot reconcile Integration %s: %v", it.Name, err)
 }
 
-// NotifyIntegrationUpdated automatically generates events when the integration changes
+// NotifyIntegrationUpdated automatically generates events when the integration changes.
 func NotifyIntegrationUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.Integration) {
 	if newResource == nil {
 		return
@@ -110,7 +110,7 @@ func NotifyIntegrationUpdated(ctx context.Context, c client.Client, recorder rec
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "Integration", newResource.Name, ReasonIntegrationPhaseUpdated, "")
 }
 
-// NotifyIntegrationKitUpdated automatically generates events when an integration kit changes
+// NotifyIntegrationKitUpdated automatically generates events when an integration kit changes.
 func NotifyIntegrationKitUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.IntegrationKit) {
 	if newResource == nil {
 		return
@@ -127,7 +127,7 @@ func NotifyIntegrationKitUpdated(ctx context.Context, c client.Client, recorder
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "Integration Kit", newResource.Name, ReasonIntegrationKitPhaseUpdated, "")
 }
 
-// NotifyIntegrationKitError automatically generates error events when the integration kit reconcile cycle phase has an error
+// NotifyIntegrationKitError automatically generates error events when the integration kit reconcile cycle phase has an error.
 func NotifyIntegrationKitError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.IntegrationKit, err error) {
 	kit := old
 	if newResource != nil {
@@ -139,7 +139,7 @@ func NotifyIntegrationKitError(ctx context.Context, c client.Client, recorder re
 	recorder.Eventf(kit, corev1.EventTypeWarning, ReasonIntegrationKitError, "Cannot reconcile Integration Kit %s: %v", kit.Name, err)
 }
 
-// NotifyIntegrationPlatformUpdated automatically generates events when an integration platform changes
+// NotifyIntegrationPlatformUpdated automatically generates events when an integration platform changes.
 func NotifyIntegrationPlatformUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.IntegrationPlatform) {
 	if newResource == nil {
 		return
@@ -156,7 +156,7 @@ func NotifyIntegrationPlatformUpdated(ctx context.Context, c client.Client, reco
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "Integration Platform", newResource.Name, ReasonIntegrationPlatformPhaseUpdated, "")
 }
 
-// NotifyIntegrationPlatformError automatically generates error events when the integration Platform reconcile cycle phase has an error
+// NotifyIntegrationPlatformError automatically generates error events when the integration Platform reconcile cycle phase has an error.
 func NotifyIntegrationPlatformError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.IntegrationPlatform, err error) {
 	p := old
 	if newResource != nil {
@@ -168,7 +168,7 @@ func NotifyIntegrationPlatformError(ctx context.Context, c client.Client, record
 	recorder.Eventf(p, corev1.EventTypeWarning, ReasonIntegrationPlatformError, "Cannot reconcile Integration Platform %s: %v", p.Name, err)
 }
 
-// NotifyKameletUpdated automatically generates events when a Kamelet changes
+// NotifyKameletUpdated automatically generates events when a Kamelet changes.
 func NotifyKameletUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1alpha1.Kamelet) {
 	if newResource == nil {
 		return
@@ -185,7 +185,7 @@ func NotifyKameletUpdated(ctx context.Context, c client.Client, recorder record.
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "Kamelet", newResource.Name, ReasonKameletPhaseUpdated, "")
 }
 
-// NotifyKameletError automatically generates error events when the kamelet reconcile cycle phase has an error
+// NotifyKameletError automatically generates error events when the kamelet reconcile cycle phase has an error.
 func NotifyKameletError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1alpha1.Kamelet, err error) {
 	k := old
 	if newResource != nil {
@@ -197,7 +197,7 @@ func NotifyKameletError(ctx context.Context, c client.Client, recorder record.Ev
 	recorder.Eventf(k, corev1.EventTypeWarning, ReasonKameletError, "Cannot reconcile Kamelet %s: %v", k.Name, err)
 }
 
-// NotifyKameletBindingUpdated automatically generates events when a KameletBinding changes
+// NotifyKameletBindingUpdated automatically generates events when a KameletBinding changes.
 func NotifyKameletBindingUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1alpha1.KameletBinding) {
 	if newResource == nil {
 		return
@@ -214,7 +214,7 @@ func NotifyKameletBindingUpdated(ctx context.Context, c client.Client, recorder
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "KameletBinding", newResource.Name, ReasonKameletBindingPhaseUpdated, "")
 }
 
-// NotifyKameletBindingError automatically generates error events when the kameletBinding reconcile cycle phase has an error
+// NotifyKameletBindingError automatically generates error events when the kameletBinding reconcile cycle phase has an error.
 func NotifyKameletBindingError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1alpha1.KameletBinding, err error) {
 	k := old
 	if newResource != nil {
@@ -226,7 +226,7 @@ func NotifyKameletBindingError(ctx context.Context, c client.Client, recorder re
 	recorder.Eventf(k, corev1.EventTypeWarning, ReasonKameletError, "Cannot reconcile KameletBinding %s: %v", k.Name, err)
 }
 
-// NotifyBuildUpdated automatically generates events when a build changes
+// NotifyBuildUpdated automatically generates events when a build changes.
 func NotifyBuildUpdated(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.Build) {
 	if newResource == nil {
 		return
@@ -249,7 +249,7 @@ func NotifyBuildUpdated(ctx context.Context, c client.Client, recorder record.Ev
 	notifyIfPhaseUpdated(ctx, c, recorder, newResource, oldPhase, string(newResource.Status.Phase), "Build", newResource.Name, ReasonBuildPhaseUpdated, info)
 }
 
-// NotifyBuildError automatically generates error events when the build reconcile cycle phase has an error
+// NotifyBuildError automatically generates error events when the build reconcile cycle phase has an error.
 func NotifyBuildError(ctx context.Context, c client.Client, recorder record.EventRecorder, old, newResource *v1.Build, err error) {
 	p := old
 	if newResource != nil {
diff --git a/pkg/install/builder.go b/pkg/install/builder.go
index 70926ad..06fc0ff 100644
--- a/pkg/install/builder.go
+++ b/pkg/install/builder.go
@@ -24,7 +24,7 @@ import (
 	"github.com/apache/camel-k/pkg/client"
 )
 
-// BuilderServiceAccountRoles installs the builder service account and related roles in the given namespace
+// BuilderServiceAccountRoles installs the builder service account and related roles in the given namespace.
 func BuilderServiceAccountRoles(ctx context.Context, c client.Client, namespace string, cluster v1.IntegrationPlatformCluster) error {
 	if cluster == v1.IntegrationPlatformClusterOpenShift {
 		if err := installBuilderServiceAccountRolesOpenShift(ctx, c, namespace); err != nil {
diff --git a/pkg/install/common.go b/pkg/install/common.go
index e8d27d3..72315ae 100644
--- a/pkg/install/common.go
+++ b/pkg/install/common.go
@@ -35,10 +35,10 @@ import (
 	"github.com/apache/camel-k/pkg/util/openshift"
 )
 
-// ResourceCustomizer can be used to inject code that changes the objects before they are created
+// ResourceCustomizer can be used to inject code that changes the objects before they are created.
 type ResourceCustomizer func(object ctrl.Object) ctrl.Object
 
-// IdentityResourceCustomizer is a ResourceCustomizer that does nothing
+// IdentityResourceCustomizer is a ResourceCustomizer that does nothing.
 var IdentityResourceCustomizer = func(object ctrl.Object) ctrl.Object {
 	return object
 }
@@ -59,7 +59,7 @@ var RemoveIngressRoleCustomizer = func(object ctrl.Object) ctrl.Object {
 	return object
 }
 
-// Resources installs named resources from the project resource directory
+// Resources installs named resources from the project resource directory.
 func Resources(ctx context.Context, c client.Client, namespace string, force bool, customizer ResourceCustomizer, names ...string) error {
 	return ResourcesOrCollect(ctx, c, namespace, nil, force, customizer, names...)
 }
@@ -74,7 +74,7 @@ func ResourcesOrCollect(ctx context.Context, c client.Client, namespace string,
 	return nil
 }
 
-// Resource installs a single named resource from the project resource directory
+// Resource installs a single named resource from the project resource directory.
 func Resource(ctx context.Context, c client.Client, namespace string, force bool, customizer ResourceCustomizer, name string) error {
 	return ResourceOrCollect(ctx, c, namespace, nil, force, customizer, name)
 }
diff --git a/pkg/install/kamelets.go b/pkg/install/kamelets.go
index 2134a48..91bebee 100644
--- a/pkg/install/kamelets.go
+++ b/pkg/install/kamelets.go
@@ -42,7 +42,7 @@ const (
 	defaultKameletDir = "/kamelets/"
 )
 
-// KameletCatalog installs the bundled KameletCatalog into one namespace
+// KameletCatalog installs the bundled KameletCatalog into one namespace.
 func KameletCatalog(ctx context.Context, c client.Client, namespace string) error {
 	kameletDir := os.Getenv(kameletDirEnv)
 	if kameletDir == "" {
@@ -112,7 +112,7 @@ func KameletCatalog(ctx context.Context, c client.Client, namespace string) erro
 	return nil
 }
 
-// KameletViewerRole installs the role that allows any user ro access kamelets in the global namespace
+// KameletViewerRole installs the role that allows any user ro access kamelets in the global namespace.
 func KameletViewerRole(ctx context.Context, c client.Client, namespace string) error {
 	if err := Resource(ctx, c, namespace, true, IdentityResourceCustomizer, "/viewer/user-global-kamelet-viewer-role.yaml"); err != nil {
 		return err
diff --git a/pkg/install/openshift.go b/pkg/install/openshift.go
index 2f5ade5..39831b4 100644
--- a/pkg/install/openshift.go
+++ b/pkg/install/openshift.go
@@ -39,23 +39,23 @@ const (
 	kamelVersionAnnotation = "camel.apache.org/version"
 )
 
-// The following variables may be overridden at build time
+// The following variables may be overridden at build time.
 var (
-	// KamelCLIDownloadName --
+	// KamelCLIDownloadName --.
 	KamelCLIDownloadName = "kamel-cli"
-	// KamelCLIDownloadDisplayName is the name as seen in the download page
+	// KamelCLIDownloadDisplayName is the name as seen in the download page.
 	KamelCLIDownloadDisplayName = "kamel - Apache Camel K Command Line Interface"
-	// KamelCLIDownloadDescription is the description as seen in the download page
+	// KamelCLIDownloadDescription is the description as seen in the download page.
 	KamelCLIDownloadDescription = "Apache Camel K is a lightweight integration platform, born on Kubernetes, with serverless superpowers.\n\n" +
 		"The `kamel` binary can be used to both configure the cluster and run integrations. " +
 		"Once you've downloaded the `kamel` binary, log into the cluster using the `oc` client tool and start using the `kamel` CLI.\n\n" +
 		"You can run `kamel help` to list the available commands or go to the [Camel K Website](https://camel.apache.org/projects/camel-k/) for more information."
 
-	// KamelCLIDownloadURLTemplate is the download template with 3 missing parameters (version, version, os)
+	// KamelCLIDownloadURLTemplate is the download template with 3 missing parameters (version, version, os).
 	KamelCLIDownloadURLTemplate = "https://github.com/apache/camel-k/releases/download/v%s/camel-k-client-%s-%s-64bit.tar.gz"
 )
 
-// OpenShiftConsoleDownloadLink installs the download link for the OpenShift console
+// OpenShiftConsoleDownloadLink installs the download link for the OpenShift console.
 func OpenShiftConsoleDownloadLink(ctx context.Context, c client.Client) error {
 	// Check the ConsoleCLIDownload CRD is present, which should be starting OpenShift version 4.2.
 	// That check is also enough to exclude Kubernetes clusters.
diff --git a/pkg/install/operator.go b/pkg/install/operator.go
index 8950451..5fcb63a 100644
--- a/pkg/install/operator.go
+++ b/pkg/install/operator.go
@@ -69,7 +69,7 @@ type OperatorMonitoringConfiguration struct {
 	Port    int32
 }
 
-// OperatorOrCollect installs the operator resources or adds them to the collector if present
+// OperatorOrCollect installs the operator resources or adds them to the collector if present.
 func OperatorOrCollect(ctx context.Context, c client.Client, cfg OperatorConfiguration, collection *kubernetes.Collection, force bool) error {
 	isOpenShift, err := isOpenShift(c, cfg.ClusterType)
 	if err != nil {
diff --git a/pkg/install/optional.go b/pkg/install/optional.go
index e4d52b6..10da131 100644
--- a/pkg/install/optional.go
+++ b/pkg/install/optional.go
@@ -27,7 +27,7 @@ import (
 	"github.com/apache/camel-k/pkg/client"
 )
 
-// OperatorStartupOptionalTools tries to install optional tools at operator startup and warns if something goes wrong
+// OperatorStartupOptionalTools tries to install optional tools at operator startup and warns if something goes wrong.
 func OperatorStartupOptionalTools(ctx context.Context, c client.Client, namespace string, operatorNamespace string, log logr.Logger) {
 	// Try to register the OpenShift CLI Download link if possible
 	if err := OpenShiftConsoleDownloadLink(ctx, c); err != nil {
diff --git a/pkg/install/secret.go b/pkg/install/secret.go
index c4a2f8b..2c197e7 100644
--- a/pkg/install/secret.go
+++ b/pkg/install/secret.go
@@ -31,7 +31,7 @@ import (
 
 const registrySecretName = "camel-k-registry-secret"
 
-// RegistrySecretOrCollect generates a secret from auth settings and creates it on the cluster (or appends it to the collection)
+// RegistrySecretOrCollect generates a secret from auth settings and creates it on the cluster (or appends it to the collection).
 func RegistrySecretOrCollect(ctx context.Context, c client.Client, namespace string, auth registry.Auth, collection *kubernetes.Collection, force bool) (string, error) {
 	secretData, err := auth.GenerateDockerConfig()
 	if err != nil {
@@ -41,7 +41,7 @@ func RegistrySecretOrCollect(ctx context.Context, c client.Client, namespace str
 	return registrySecretFromDataOrCollect(ctx, c, namespace, secretData, collection, force)
 }
 
-// RegistrySecretFromFileOrCollect generates a secret from a docker-config.json file and creates it on the cluster (or appends it to the collection)
+// RegistrySecretFromFileOrCollect generates a secret from a docker-config.json file and creates it on the cluster (or appends it to the collection).
 func RegistrySecretFromFileOrCollect(ctx context.Context, c client.Client, namespace string, file string, collection *kubernetes.Collection, force bool) (string, error) {
 	secretData, err := util.ReadFile(file)
 	if err != nil {
@@ -51,7 +51,7 @@ func RegistrySecretFromFileOrCollect(ctx context.Context, c client.Client, names
 	return registrySecretFromDataOrCollect(ctx, c, namespace, secretData, collection, force)
 }
 
-// registrySecretFromDataOrCollect generates a secret from a docker config file content file and creates it on the cluster (or appends it to the collection)
+// registrySecretFromDataOrCollect generates a secret from a docker config file content file and creates it on the cluster (or appends it to the collection).
 func registrySecretFromDataOrCollect(ctx context.Context, c client.Client, namespace string, secretData []byte, collection *kubernetes.Collection, force bool) (string, error) {
 	registrySecret := v1.Secret{
 		TypeMeta: metav1.TypeMeta{
diff --git a/pkg/metadata/metadata.go b/pkg/metadata/metadata.go
index 03c8ca1..02ab8f8 100644
--- a/pkg/metadata/metadata.go
+++ b/pkg/metadata/metadata.go
@@ -25,7 +25,7 @@ import (
 	src "github.com/apache/camel-k/pkg/util/source"
 )
 
-// ExtractAll returns metadata information from all listed source codes
+// ExtractAll returns metadata information from all listed source codes.
 func ExtractAll(catalog *camel.RuntimeCatalog, sources []v1.SourceSpec) IntegrationMetadata {
 	// neutral metadata
 	meta := src.NewMetadata()
@@ -59,7 +59,7 @@ func merge(m1 src.Metadata, m2 src.Metadata) src.Metadata {
 	}
 }
 
-// Extract returns metadata information from the source code
+// Extract returns metadata information from the source code.
 func Extract(catalog *camel.RuntimeCatalog, source v1.SourceSpec) IntegrationMetadata {
 	if source.ContentRef != "" {
 		panic("source must be dereferenced before calling this method")
@@ -82,7 +82,7 @@ func Extract(catalog *camel.RuntimeCatalog, source v1.SourceSpec) IntegrationMet
 	}
 }
 
-// Each --
+// Each --.
 func Each(catalog *camel.RuntimeCatalog, sources []v1.SourceSpec, consumer func(int, IntegrationMetadata) bool) {
 	for i, s := range sources {
 		meta := Extract(catalog, s)
diff --git a/pkg/metadata/types.go b/pkg/metadata/types.go
index 66565cf..2af13a6 100644
--- a/pkg/metadata/types.go
+++ b/pkg/metadata/types.go
@@ -21,7 +21,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/source"
 )
 
-// IntegrationMetadata contains aggregate metadata about all Camel routes in a integrations
+// IntegrationMetadata contains aggregate metadata about all Camel routes in a integrations.
 type IntegrationMetadata struct {
 	source.Metadata
 }
diff --git a/pkg/platform/defaults.go b/pkg/platform/defaults.go
index ee8302d..45bc09a 100644
--- a/pkg/platform/defaults.go
+++ b/pkg/platform/defaults.go
@@ -45,7 +45,7 @@ import (
 	"github.com/apache/camel-k/pkg/util/patch"
 )
 
-// BuilderServiceAccount --
+// BuilderServiceAccount --.
 const BuilderServiceAccount = "camel-k-builder"
 
 // ConfigureDefaults fills with default values all missing details about the integration platform.
diff --git a/pkg/platform/operator.go b/pkg/platform/operator.go
index 327c1cd..c9fe67c 100644
--- a/pkg/platform/operator.go
+++ b/pkg/platform/operator.go
@@ -42,7 +42,7 @@ const OperatorLockName = "camel-k-lock"
 
 var OperatorImage string
 
-// IsCurrentOperatorGlobal returns true if the operator is configured to watch all namespaces
+// IsCurrentOperatorGlobal returns true if the operator is configured to watch all namespaces.
 func IsCurrentOperatorGlobal() bool {
 	if watchNamespace, envSet := os.LookupEnv(OperatorWatchNamespaceEnvVariable); !envSet || strings.TrimSpace(watchNamespace) == "" {
 		return true
@@ -50,7 +50,7 @@ func IsCurrentOperatorGlobal() bool {
 	return false
 }
 
-// GetOperatorWatchNamespace returns the namespace the operator watches
+// GetOperatorWatchNamespace returns the namespace the operator watches.
 func GetOperatorWatchNamespace() string {
 	if namespace, envSet := os.LookupEnv(OperatorWatchNamespaceEnvVariable); envSet {
 		return namespace
@@ -58,7 +58,7 @@ func GetOperatorWatchNamespace() string {
 	return ""
 }
 
-// GetOperatorNamespace returns the namespace where the current operator is located (if set)
+// GetOperatorNamespace returns the namespace where the current operator is located (if set).
 func GetOperatorNamespace() string {
 	if podNamespace, envSet := os.LookupEnv(operatorNamespaceEnvVariable); envSet {
 		return podNamespace
@@ -66,7 +66,7 @@ func GetOperatorNamespace() string {
 	return ""
 }
 
-// GetOperatorPodName returns the pod that is running the current operator (if any)
+// GetOperatorPodName returns the pod that is running the current operator (if any).
 func GetOperatorPodName() string {
 	if podName, envSet := os.LookupEnv(operatorPodNameEnvVariable); envSet {
 		return podName
@@ -74,7 +74,7 @@ func GetOperatorPodName() string {
 	return ""
 }
 
-// IsNamespaceLocked tells if the namespace contains a lock indicating that an operator owns it
+// IsNamespaceLocked tells if the namespace contains a lock indicating that an operator owns it.
 func IsNamespaceLocked(ctx context.Context, c ctrl.Reader, namespace string) (bool, error) {
 	if namespace == "" {
 		return false, nil
@@ -89,7 +89,7 @@ func IsNamespaceLocked(ctx context.Context, c ctrl.Reader, namespace string) (bo
 	return true, nil
 }
 
-// IsOperatorAllowedOnNamespace returns true if the current operator is allowed to react on changes in the given namespace
+// IsOperatorAllowedOnNamespace returns true if the current operator is allowed to react on changes in the given namespace.
 func IsOperatorAllowedOnNamespace(ctx context.Context, c ctrl.Reader, namespace string) (bool, error) {
 	if !IsCurrentOperatorGlobal() {
 		return true, nil
diff --git a/pkg/platform/platform.go b/pkg/platform/platform.go
index f0abb99..8c3af7a 100644
--- a/pkg/platform/platform.go
+++ b/pkg/platform/platform.go
@@ -27,7 +27,7 @@ import (
 )
 
 const (
-	// DefaultPlatformName is the standard name used for the integration platform
+	// DefaultPlatformName is the standard name used for the integration platform.
 	DefaultPlatformName = "camel-k"
 )
 
@@ -62,7 +62,7 @@ func getOrFind(ctx context.Context, c k8sclient.Reader, namespace string, name s
 	return getOrFindAny(ctx, c, namespace, name, active)
 }
 
-// getOrFindAny returns the named platform or any other platform in the local namespace or the global one
+// getOrFindAny returns the named platform or any other platform in the local namespace or the global one.
 func getOrFindAny(ctx context.Context, c k8sclient.Reader, namespace string, name string, active bool) (*v1.IntegrationPlatform, error) {
 	if name != "" {
 		return get(ctx, c, namespace, name)
@@ -71,7 +71,7 @@ func getOrFindAny(ctx context.Context, c k8sclient.Reader, namespace string, nam
 	return findAny(ctx, c, namespace, active)
 }
 
-// getOrFindLocal returns the named platform or any other platform in the local namespace
+// getOrFindLocal returns the named platform or any other platform in the local namespace.
 func getOrFindLocal(ctx context.Context, c k8sclient.Reader, namespace string, name string, active bool) (*v1.IntegrationPlatform, error) {
 	if name != "" {
 		return kubernetes.GetIntegrationPlatform(ctx, c, name, namespace)
@@ -80,7 +80,7 @@ func getOrFindLocal(ctx context.Context, c k8sclient.Reader, namespace string, n
 	return findLocal(ctx, c, namespace, active)
 }
 
-// get returns the given platform in the given namespace or the global one
+// get returns the given platform in the given namespace or the global one.
 func get(ctx context.Context, c k8sclient.Reader, namespace string, name string) (*v1.IntegrationPlatform, error) {
 	p, err := kubernetes.GetIntegrationPlatform(ctx, c, name, namespace)
 	if err != nil && k8serrors.IsNotFound(err) {
@@ -99,7 +99,7 @@ func find(ctx context.Context, c k8sclient.Reader, namespace string, active bool
 	return findAny(ctx, c, namespace, active)
 }
 
-// findAny returns the currently installed platform or any platform existing in local or operator namespace
+// findAny returns the currently installed platform or any platform existing in local or operator namespace.
 func findAny(ctx context.Context, c k8sclient.Reader, namespace string, active bool) (*v1.IntegrationPlatform, error) {
 	p, err := findLocal(ctx, c, namespace, active)
 	if err != nil && k8serrors.IsNotFound(err) {
@@ -111,7 +111,7 @@ func findAny(ctx context.Context, c k8sclient.Reader, namespace string, active b
 	return p, err
 }
 
-// findLocal returns the currently installed platform or any platform existing in local namespace
+// findLocal returns the currently installed platform or any platform existing in local namespace.
 func findLocal(ctx context.Context, c k8sclient.Reader, namespace string, active bool) (*v1.IntegrationPlatform, error) {
 	lst, err := ListPrimaryPlatforms(ctx, c, namespace)
 	if err != nil {
@@ -134,7 +134,7 @@ func findLocal(ctx context.Context, c k8sclient.Reader, namespace string, active
 	return nil, k8serrors.NewNotFound(v1.Resource("IntegrationPlatform"), DefaultPlatformName)
 }
 
-// ListPrimaryPlatforms returns all non-secondary platforms installed in a given namespace (only one will be active)
+// ListPrimaryPlatforms returns all non-secondary platforms installed in a given namespace (only one will be active).
 func ListPrimaryPlatforms(ctx context.Context, c k8sclient.Reader, namespace string) (*v1.IntegrationPlatformList, error) {
 	lst, err := ListAllPlatforms(ctx, c, namespace)
 	if err != nil {
@@ -150,7 +150,7 @@ func ListPrimaryPlatforms(ctx context.Context, c k8sclient.Reader, namespace str
 	return &filtered, nil
 }
 
-// ListAllPlatforms returns all platforms installed in a given namespace
+// ListAllPlatforms returns all platforms installed in a given namespace.
 func ListAllPlatforms(ctx context.Context, c k8sclient.Reader, namespace string) (*v1.IntegrationPlatformList, error) {
 	lst := v1.NewIntegrationPlatformList()
 	if err := c.List(ctx, &lst, k8sclient.InNamespace(namespace)); err != nil {
@@ -159,12 +159,12 @@ func ListAllPlatforms(ctx context.Context, c k8sclient.Reader, namespace string)
 	return &lst, nil
 }
 
-// IsActive determines if the given platform is being used
+// IsActive determines if the given platform is being used.
 func IsActive(p *v1.IntegrationPlatform) bool {
 	return p.Status.Phase != "" && p.Status.Phase != v1.IntegrationPlatformPhaseDuplicate
 }
 
-// IsSecondary determines if the given platform is marked as secondary
+// IsSecondary determines if the given platform is marked as secondary.
 func IsSecondary(p *v1.IntegrationPlatform) bool {
 	if l, ok := p.Annotations[v1.SecondaryPlatformAnnotation]; ok && l == "true" {
 		return true
@@ -172,7 +172,7 @@ func IsSecondary(p *v1.IntegrationPlatform) bool {
 	return false
 }
 
-// GetProfile returns the current profile of the platform (if present) or returns the default one for the cluster
+// GetProfile returns the current profile of the platform (if present) or returns the default one for the cluster.
 func GetProfile(p *v1.IntegrationPlatform) v1.TraitProfile {
 	if p.Status.Profile != "" {
 		return p.Status.Profile
diff --git a/pkg/platform/resources.go b/pkg/platform/resources.go
index cc634f1..a75f501 100644
--- a/pkg/platform/resources.go
+++ b/pkg/platform/resources.go
@@ -19,24 +19,24 @@ package platform
 
 import "strings"
 
-// DefaultKits --
+// DefaultKits --.
 var DefaultKits = []string{
 	"platform-integration-kit-jvm.yaml",
 	"platform-integration-kit-groovy.yaml",
 	"platform-integration-kit-kotlin.yaml",
 }
 
-// KnativeKits --
+// KnativeKits --.
 var KnativeKits = []string{
 	"platform-integration-kit-knative.yaml",
 }
 
-// GetKits --
+// GetKits --.
 func GetKits() []string {
 	return append(DefaultKits, KnativeKits...)
 }
 
-// GetKitsNames --
+// GetKitsNames --.
 func GetKitsNames() []string {
 	ctxs := GetKits()
 	names := make([]string, 0, len(ctxs))
diff --git a/pkg/resources/resources_support.go b/pkg/resources/resources_support.go
index 930b651..d9bb2e1 100644
--- a/pkg/resources/resources_support.go
+++ b/pkg/resources/resources_support.go
@@ -30,12 +30,12 @@ import (
 //
 //go:generate go run ../../cmd/util/vfs-gen resources config
 //
-// ResourceAsString returns the named resource content as string
+// ResourceAsString returns the named resource content as string.
 func ResourceAsString(name string) string {
 	return string(Resource(name))
 }
 
-// Resource provides an easy access to embedded assets
+// Resource provides an easy access to embedded assets.
 func Resource(name string) []byte {
 	name = strings.Trim(name, " ")
 	if !strings.HasPrefix(name, "/") {
@@ -57,7 +57,7 @@ func Resource(name string) []byte {
 	return data
 }
 
-// TemplateResource loads a file resource as go template and processes it using the given parameters
+// TemplateResource loads a file resource as go template and processes it using the given parameters.
 func TemplateResource(name string, params interface{}) (string, error) {
 	rawData := ResourceAsString(name)
 	if rawData == "" {
@@ -75,7 +75,7 @@ func TemplateResource(name string, params interface{}) (string, error) {
 	return buf.String(), nil
 }
 
-// DirExists tells if a directory exists and can be listed for files
+// DirExists tells if a directory exists and can be listed for files.
 func DirExists(dirName string) bool {
 	if _, err := assets.Open(dirName); err != nil {
 		return false
@@ -84,7 +84,7 @@ func DirExists(dirName string) bool {
 }
 
 // WithPrefix lists all file names that begins with the give path prefix
-// If pathPrefix is a path of directories then be sure to end it with a '/'
+// If pathPrefix is a path of directories then be sure to end it with a '/'.
 func WithPrefix(pathPrefix string) []string {
 	dirPath := filepath.Dir(pathPrefix)
 
@@ -98,7 +98,7 @@ func WithPrefix(pathPrefix string) []string {
 	return res
 }
 
-// Resources lists all file names in the given path (starts with '/')
+// Resources lists all file names in the given path (starts with '/').
 func Resources(dirName string) []string {
 	dir, err := assets.Open(dirName)
 	if err != nil {
diff --git a/pkg/trait/affinity.go b/pkg/trait/affinity.go
index dcb9c0c..089e478 100644
--- a/pkg/trait/affinity.go
+++ b/pkg/trait/affinity.go
@@ -34,7 +34,7 @@ import (
 //
 // It's disabled by default.
 //
-// +camel-k:trait=affinity
+// +camel-k:trait=affinity.
 type affinityTrait struct {
 	BaseTrait `property:",squash"`
 	// Always co-locates multiple replicas of the integration in the same node (default *false*).
diff --git a/pkg/trait/builder.go b/pkg/trait/builder.go
index 03db319..e14f282 100644
--- a/pkg/trait/builder.go
+++ b/pkg/trait/builder.go
@@ -32,7 +32,7 @@ import (
 // The builder trait is internally used to determine the best strategy to
 // build and configure IntegrationKits.
 //
-// +camel-k:trait=builder
+// +camel-k:trait=builder.
 type builderTrait struct {
 	BaseTrait `property:",squash"`
 	// Enable verbose logging on build components that support it (e.g. Kaniko build pod).
@@ -47,12 +47,12 @@ func newBuilderTrait() Trait {
 	}
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *builderTrait) IsPlatformTrait() bool {
 	return true
 }
 
-// InfluencesKit overrides base class method
+// InfluencesKit overrides base class method.
 func (t *builderTrait) InfluencesKit() bool {
 	return true
 }
diff --git a/pkg/trait/camel.go b/pkg/trait/camel.go
index 726ded4..f774421 100644
--- a/pkg/trait/camel.go
+++ b/pkg/trait/camel.go
@@ -36,7 +36,7 @@ import (
 
 // The Camel trait can be used to configure versions of Apache Camel K runtime and related libraries, it cannot be disabled.
 //
-// +camel-k:trait=camel
+// +camel-k:trait=camel.
 type camelTrait struct {
 	BaseTrait `property:",squash"`
 	// The camel-k-runtime version to use for the integration. It overrides the default version set in the Integration Platform.
@@ -165,7 +165,7 @@ func (t *camelTrait) determineRuntimeVersion(e *Environment) string {
 	return e.Platform.Status.Build.RuntimeVersion
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *camelTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/container.go b/pkg/trait/container.go
index b0f5bf5..7ae6164 100644
--- a/pkg/trait/container.go
+++ b/pkg/trait/container.go
@@ -173,7 +173,7 @@ func (t *containerTrait) Apply(e *Environment) error {
 	return t.configureContainer(e)
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *containerTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/cron.go b/pkg/trait/cron.go
index a1b4e21..dbfeb55 100644
--- a/pkg/trait/cron.go
+++ b/pkg/trait/cron.go
@@ -50,7 +50,7 @@ import (
 // - `cron`, `quartz`: when the cron expression does not contain seconds (or the "seconds" part is set to 0). E.g.
 //   `cron:tab?schedule=0/2${plus}*{plus}*{plus}*{plus}?` or `quartz:trigger?cron=0{plus}0/2{plus}*{plus}*{plus}*{plus}?`.
 //
-// +camel-k:trait=cron
+// +camel-k:trait=cron.
 type cronTrait struct {
 	BaseTrait `property:",squash"`
 	// The CronJob schedule for the whole integration. If multiple routes are declared, they must have the same schedule for this
@@ -91,13 +91,13 @@ type cronTrait struct {
 
 var _ ControllerStrategySelector = &cronTrait{}
 
-// cronInfo contains information about cron schedules present in the code
+// cronInfo contains information about cron schedules present in the code.
 type cronInfo struct {
 	components []string
 	schedule   string
 }
 
-// cronExtractor extracts cron information from a Camel URI
+// cronExtractor extracts cron information from a Camel URI.
 type cronExtractor func(string) *cronInfo
 
 const (
@@ -321,7 +321,7 @@ func (t *cronTrait) getCronJobFor(e *Environment) *batchv1beta1.CronJob {
 	return &cronjob
 }
 
-// SelectControllerStrategy can be used to check if a CronJob can be generated given the integration and trait settings
+// SelectControllerStrategy can be used to check if a CronJob can be generated given the integration and trait settings.
 func (t *cronTrait) SelectControllerStrategy(e *Environment) (*ControllerStrategy, error) {
 	cronStrategy := ControllerStrategyCronJob
 	if IsFalse(t.Enabled) {
@@ -465,7 +465,7 @@ func timerToCronInfo(camelURI string) *cronInfo {
 	return nil
 }
 
-// quartzToCronInfo converts a quartz endpoint to a Kubernetes cron schedule
+// quartzToCronInfo converts a quartz endpoint to a Kubernetes cron schedule.
 func quartzToCronInfo(camelURI string) *cronInfo {
 	if uri.GetQueryParameter(camelURI, "fireNow") != "" ||
 		uri.GetQueryParameter(camelURI, "customCalendar") != "" ||
@@ -482,7 +482,7 @@ func quartzToCronInfo(camelURI string) *cronInfo {
 	return nil
 }
 
-// cronToCronInfo converts a cron endpoint to a Kubernetes cron schedule
+// cronToCronInfo converts a cron endpoint to a Kubernetes cron schedule.
 func cronToCronInfo(camelURI string) *cronInfo {
 	// Camel cron URIs have 5 to 7 components.
 	schedule := uri.GetQueryParameter(camelURI, "schedule")
diff --git a/pkg/trait/dependencies.go b/pkg/trait/dependencies.go
index 2a5623d..00b0391 100644
--- a/pkg/trait/dependencies.go
+++ b/pkg/trait/dependencies.go
@@ -29,7 +29,7 @@ import (
 // The Dependencies trait is internally used to automatically add runtime dependencies based on the
 // integration that the user wants to run.
 //
-// +camel-k:trait=dependencies
+// +camel-k:trait=dependencies.
 type dependenciesTrait struct {
 	BaseTrait `property:",squash"`
 }
@@ -88,7 +88,7 @@ func (t *dependenciesTrait) Apply(e *Environment) error {
 	return nil
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *dependenciesTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/dependencies_test.go b/pkg/trait/dependencies_test.go
index 8a01e6e..d0e8eda 100644
--- a/pkg/trait/dependencies_test.go
+++ b/pkg/trait/dependencies_test.go
@@ -203,7 +203,7 @@ func TestIntegrationAutoGeneratedDeps(t *testing.T) {
 
 // in this test the language of the source is something unrelated to the
 // loader to test the order in which loader and language are taken into
-// account when dependencies are computed
+// account when dependencies are computed.
 func TestIntegrationCustomLoader(t *testing.T) {
 	catalog, err := camel.DefaultCatalog()
 	assert.Nil(t, err)
diff --git a/pkg/trait/deployer.go b/pkg/trait/deployer.go
index e060b86..67cdb79 100644
--- a/pkg/trait/deployer.go
+++ b/pkg/trait/deployer.go
@@ -36,7 +36,7 @@ import (
 // The deployer trait is responsible for deploying the resources owned by the integration, and can be used
 // to explicitly select the underlying controller that will manage the integration pods.
 //
-// +camel-k:trait=deployer
+// +camel-k:trait=deployer.
 type deployerTrait struct {
 	BaseTrait `property:",squash"`
 	// Allows to explicitly select the desired deployment kind between `deployment`, `cron-job` or `knative-service` when creating the resources for running the integration.
@@ -173,12 +173,12 @@ func (t *deployerTrait) ControllerStrategySelectorOrder() int {
 	return 0
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *deployerTrait) IsPlatformTrait() bool {
 	return true
 }
 
-// RequiresIntegrationPlatform overrides base class method
+// RequiresIntegrationPlatform overrides base class method.
 func (t *deployerTrait) RequiresIntegrationPlatform() bool {
 	return false
 }
diff --git a/pkg/trait/deployment.go b/pkg/trait/deployment.go
index 283c783..c237732 100644
--- a/pkg/trait/deployment.go
+++ b/pkg/trait/deployment.go
@@ -31,7 +31,7 @@ import (
 // The Deployment trait is responsible for generating the Kubernetes deployment that will make sure
 // the integration will run in the cluster.
 //
-// +camel-k:trait=deployment
+// +camel-k:trait=deployment.
 type deploymentTrait struct {
 	BaseTrait `property:",squash"`
 	// The maximum time in seconds for the deployment to make progress before it
@@ -115,7 +115,7 @@ func (t *deploymentTrait) Apply(e *Environment) error {
 	return nil
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *deploymentTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/environment.go b/pkg/trait/environment.go
index ead510f..3f96d24 100644
--- a/pkg/trait/environment.go
+++ b/pkg/trait/environment.go
@@ -26,7 +26,7 @@ import (
 // The environment trait is used internally to inject standard environment variables in the integration container,
 // such as `NAMESPACE`, `POD_NAME` and others.
 //
-// +camel-k:trait=environment
+// +camel-k:trait=environment.
 type environmentTrait struct {
 	BaseTrait `property:",squash"`
 	// Enables injection of `NAMESPACE` and `POD_NAME` environment variables (default `true`)
@@ -91,7 +91,7 @@ func (t *environmentTrait) Apply(e *Environment) error {
 	return nil
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *environmentTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/error_handler.go b/pkg/trait/error_handler.go
index 571e4ec..f11d107 100644
--- a/pkg/trait/error_handler.go
+++ b/pkg/trait/error_handler.go
@@ -29,7 +29,7 @@ import (
 
 // The error-handler is a platform trait used to inject Error Handler source into the integration runtime.
 //
-// +camel-k:trait=error-handler
+// +camel-k:trait=error-handler.
 type errorHandlerTrait struct {
 	BaseTrait `property:",squash"`
 	// The error handler ref name provided or found in application properties
@@ -43,7 +43,7 @@ func newErrorHandlerTrait() Trait {
 	}
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *errorHandlerTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/gc.go b/pkg/trait/gc.go
index 8eb4b82..1ff3204 100644
--- a/pkg/trait/gc.go
+++ b/pkg/trait/gc.go
@@ -58,7 +58,7 @@ const (
 
 // The GC Trait garbage-collects all resources that are no longer necessary upon integration updates.
 //
-// +camel-k:trait=gc
+// +camel-k:trait=gc.
 type garbageCollectorTrait struct {
 	BaseTrait `property:",squash"`
 	// Discovery client cache to be used, either `disabled`, `disk` or `memory` (default `memory`)
diff --git a/pkg/trait/health.go b/pkg/trait/health.go
index 0d60ca4..f5943a0 100644
--- a/pkg/trait/health.go
+++ b/pkg/trait/health.go
@@ -37,7 +37,7 @@ const (
 //
 // It's disabled by default.
 //
-// +camel-k:trait=health
+// +camel-k:trait=health.
 type healthTrait struct {
 	BaseTrait `property:",squash"`
 
diff --git a/pkg/trait/ingress.go b/pkg/trait/ingress.go
index 24115fa..a5e2b7e 100644
--- a/pkg/trait/ingress.go
+++ b/pkg/trait/ingress.go
@@ -33,7 +33,7 @@ import (
 //
 // It's enabled by default whenever a Service is added to the integration (through the `service` trait).
 //
-// +camel-k:trait=ingress
+// +camel-k:trait=ingress.
 type ingressTrait struct {
 	BaseTrait `property:",squash"`
 	// **Required**. To configure the host exposed by the ingress.
@@ -49,7 +49,7 @@ func newIngressTrait() Trait {
 	}
 }
 
-// IsAllowedInProfile overrides default
+// IsAllowedInProfile overrides default.
 func (t *ingressTrait) IsAllowedInProfile(profile v1.TraitProfile) bool {
 	return profile == v1.TraitProfileKubernetes
 }
diff --git a/pkg/trait/istio.go b/pkg/trait/istio.go
index fd48559..58b6547 100644
--- a/pkg/trait/istio.go
+++ b/pkg/trait/istio.go
@@ -28,7 +28,7 @@ import (
 // The Istio trait allows configuring properties related to the Istio service mesh,
 // such as sidecar injection and outbound IP ranges.
 //
-// +camel-k:trait=istio
+// +camel-k:trait=istio.
 type istioTrait struct {
 	BaseTrait `property:",squash"`
 	// Configures a (comma-separated) list of CIDR subnets that should not be intercepted by the Istio proxy (`10.0.0.0/8,172.16.0.0/12,192.168.0.0/16` by default).
diff --git a/pkg/trait/jvm.go b/pkg/trait/jvm.go
index 7d1991a..4787ca3 100644
--- a/pkg/trait/jvm.go
+++ b/pkg/trait/jvm.go
@@ -41,7 +41,7 @@ import (
 
 // The JVM trait is used to configure the JVM that runs the integration.
 //
-// +camel-k:trait=jvm
+// +camel-k:trait=jvm.
 type jvmTrait struct {
 	BaseTrait `property:",squash"`
 	// Activates remote debugging, so that a debugger can be attached to the JVM, e.g., using port-forwarding
@@ -209,7 +209,7 @@ func (t *jvmTrait) Apply(e *Environment) error {
 	return nil
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *jvmTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/kamelets.go b/pkg/trait/kamelets.go
index 3ca7e43..06d2122 100644
--- a/pkg/trait/kamelets.go
+++ b/pkg/trait/kamelets.go
@@ -42,7 +42,7 @@ import (
 
 // The kamelets trait is a platform trait used to inject Kamelets into the integration runtime.
 //
-// +camel-k:trait=kamelets
+// +camel-k:trait=kamelets.
 type kameletsTrait struct {
 	BaseTrait `property:",squash"`
 	// Automatically inject all referenced Kamelets and their default configuration (enabled by default)
@@ -76,7 +76,7 @@ func newKameletsTrait() Trait {
 	}
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *kameletsTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/knative.go b/pkg/trait/knative.go
index 03ecfb3..f3b611b 100644
--- a/pkg/trait/knative.go
+++ b/pkg/trait/knative.go
@@ -52,7 +52,7 @@ import (
 //
 // The trait is enabled by default when the Knative profile is active.
 //
-// +camel-k:trait=knative
+// +camel-k:trait=knative.
 type knativeTrait struct {
 	BaseTrait `property:",squash"`
 	// Can be used to inject a Knative complete configuration in JSON format.
@@ -98,7 +98,7 @@ func newKnativeTrait() Trait {
 	return t
 }
 
-// IsAllowedInProfile overrides default
+// IsAllowedInProfile overrides default.
 func (t *knativeTrait) IsAllowedInProfile(profile v1.TraitProfile) bool {
 	return profile == v1.TraitProfileKnative
 }
diff --git a/pkg/trait/knative_service.go b/pkg/trait/knative_service.go
index 2b01dd1..82576f9 100644
--- a/pkg/trait/knative_service.go
+++ b/pkg/trait/knative_service.go
@@ -35,13 +35,13 @@ import (
 const (
 	knativeServiceTraitID = "knative-service"
 
-	// Auto-scaling annotations
+	// Auto-scaling annotations.
 	knativeServingClassAnnotation    = "autoscaling.knative.dev/class"
 	knativeServingMetricAnnotation   = "autoscaling.knative.dev/metric"
 	knativeServingTargetAnnotation   = "autoscaling.knative.dev/target"
 	knativeServingMinScaleAnnotation = "autoscaling.knative.dev/minScale"
 	knativeServingMaxScaleAnnotation = "autoscaling.knative.dev/maxScale"
-	// Rollout annotation
+	// Rollout annotation.
 	knativeServingRolloutDurationAnnotation = "serving.knative.dev/rolloutDuration"
 )
 
@@ -51,7 +51,7 @@ const (
 // Running an Integration as a Knative Service enables auto-scaling (and scaling-to-zero), but those features
 // are only relevant when the Camel route(s) use(s) an HTTP endpoint consumer.
 //
-// +camel-k:trait=knative-service
+// +camel-k:trait=knative-service.
 type knativeServiceTrait struct {
 	BaseTrait `property:",squash"`
 	// Configures the Knative autoscaling class property (e.g. to set `hpa.autoscaling.knative.dev` or `kpa.autoscaling.knative.dev` autoscaling).
@@ -95,7 +95,7 @@ func newKnativeServiceTrait() Trait {
 	}
 }
 
-// IsAllowedInProfile overrides default
+// IsAllowedInProfile overrides default.
 func (t *knativeServiceTrait) IsAllowedInProfile(profile v1.TraitProfile) bool {
 	return profile == v1.TraitProfileKnative
 }
diff --git a/pkg/trait/logging.go b/pkg/trait/logging.go
index 178deae..5c80a4c 100644
--- a/pkg/trait/logging.go
+++ b/pkg/trait/logging.go
@@ -33,7 +33,7 @@ const (
 // The Logging trait is used to configure Integration runtime logging options (such as color and format).
 // The logging backend is provided by Quarkus, whose configuration is documented at https://quarkus.io/guides/logging.
 //
-// +camel-k:trait=logging
+// +camel-k:trait=logging.
 type loggingTrait struct {
 	BaseTrait `property:",squash"`
 	// Colorize the log output
diff --git a/pkg/trait/openapi.go b/pkg/trait/openapi.go
index 6a7a9ed..272714d 100644
--- a/pkg/trait/openapi.go
+++ b/pkg/trait/openapi.go
@@ -47,7 +47,7 @@ import (
 
 // The OpenAPI DSL trait is internally used to allow creating integrations from a OpenAPI specs.
 //
-// +camel-k:trait=openapi
+// +camel-k:trait=openapi.
 type openAPITrait struct {
 	BaseTrait `property:",squash"`
 }
@@ -58,7 +58,7 @@ func newOpenAPITrait() Trait {
 	}
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *openAPITrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/owner.go b/pkg/trait/owner.go
index 3a95b77..c14eb75 100644
--- a/pkg/trait/owner.go
+++ b/pkg/trait/owner.go
@@ -29,7 +29,7 @@ import (
 // The Owner trait ensures that all created resources belong to the integration being created
 // and transfers annotations and labels on the integration onto these owned resources.
 //
-// +camel-k:trait=owner
+// +camel-k:trait=owner.
 type ownerTrait struct {
 	BaseTrait `property:",squash"`
 	// The set of annotations to be transferred
@@ -111,7 +111,7 @@ func (t *ownerTrait) Apply(e *Environment) error {
 	return nil
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *ownerTrait) IsPlatformTrait() bool {
 	return true
 }
diff --git a/pkg/trait/pdb.go b/pkg/trait/pdb.go
index 4a334c5..f0b5636 100644
--- a/pkg/trait/pdb.go
+++ b/pkg/trait/pdb.go
@@ -29,7 +29,7 @@ import (
 
 // The PDB trait allows to configure the PodDisruptionBudget resource for the Integration pods.
 //
-// +camel-k:trait=pdb
+// +camel-k:trait=pdb.
 type pdbTrait struct {
 	BaseTrait `property:",squash"`
 	// The number of pods for the Integration that must still be available after an eviction.
diff --git a/pkg/trait/platform.go b/pkg/trait/platform.go
index e273040..46d9fba 100644
--- a/pkg/trait/platform.go
+++ b/pkg/trait/platform.go
@@ -31,7 +31,7 @@ import (
 // This feature is especially useful in contexts where there's no need to provide a custom configuration for the platform
 // (e.g. on OpenShift the default settings work, since there's an embedded container image registry).
 //
-// +camel-k:trait=platform
+// +camel-k:trait=platform.
 type platformTrait struct {
 	BaseTrait `property:",squash"`
 	// To create a default (empty) platform when the platform is missing.
@@ -128,12 +128,12 @@ func (t *platformTrait) getOrCreatePlatform(e *Environment) (*v1.IntegrationPlat
 	return pl, err
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *platformTrait) IsPlatformTrait() bool {
 	return true
 }
 
-// RequiresIntegrationPlatform overrides base class method
+// RequiresIntegrationPlatform overrides base class method.
 func (t *platformTrait) RequiresIntegrationPlatform() bool {
 	return false
 }
diff --git a/pkg/trait/pod.go b/pkg/trait/pod.go
index 7af2edd..b3722f3 100644
--- a/pkg/trait/pod.go
+++ b/pkg/trait/pod.go
@@ -38,7 +38,7 @@ import (
 // This can be used to customize the container where Camel routes execute,
 // by using the `integration` container name.
 //
-// +camel-k:trait=pod
+// +camel-k:trait=pod.
 type podTrait struct {
 	BaseTrait `property:",squash"`
 }
diff --git a/pkg/trait/prometheus.go b/pkg/trait/prometheus.go
index 9dae4c8..bf9113e 100644
--- a/pkg/trait/prometheus.go
+++ b/pkg/trait/prometheus.go
@@ -40,7 +40,7 @@ import (
 //
 // The Prometheus trait is disabled by default.
 //
-// +camel-k:trait=prometheus
+// +camel-k:trait=prometheus.
 type prometheusTrait struct {
 	BaseTrait `property:",squash"`
 	// Whether a `PodMonitor` resource is created (default `true`).
diff --git a/pkg/trait/pull_secret.go b/pkg/trait/pull_secret.go
index 10779e3..10414e5 100644
--- a/pkg/trait/pull_secret.go
+++ b/pkg/trait/pull_secret.go
@@ -44,7 +44,7 @@ import (
 //
 // If your registry does not need authentication for pulling images, you can disable this trait.
 //
-// +camel-k:trait=pull-secret
+// +camel-k:trait=pull-secret.
 type pullSecretTrait struct {
 	BaseTrait `property:",squash"`
 	// The pull secret name to set on the Pod. If left empty this is automatically taken from the `IntegrationPlatform` registry configuration.
diff --git a/pkg/trait/quarkus.go b/pkg/trait/quarkus.go
index c1c37b6..f93de9c 100644
--- a/pkg/trait/quarkus.go
+++ b/pkg/trait/quarkus.go
@@ -56,7 +56,7 @@ var kitPriority = map[quarkusPackageType]string{
 // the operator Pod, or the build Pod (depending on the build strategy configured for the platform),
 // must have enough memory available.
 //
-// +camel-k:trait=quarkus
+// +camel-k:trait=quarkus.
 type quarkusTrait struct {
 	BaseTrait `property:",squash"`
 	// The Quarkus package types, either `fast-jar` or `native` (default `fast-jar`).
@@ -74,12 +74,12 @@ func newQuarkusTrait() Trait {
 	}
 }
 
-// IsPlatformTrait overrides base class method
+// IsPlatformTrait overrides base class method.
 func (t *quarkusTrait) IsPlatformTrait() bool {
 	return true
 }
 
-// InfluencesKit overrides base class method
+// InfluencesKit overrides base class method.
 func (t *quarkusTrait) InfluencesKit() bool {
 	return true
 }
diff --git a/pkg/trait/route.go b/pkg/trait/route.go
index 63b1d15..c3d5417 100644
--- a/pkg/trait/route.go
+++ b/pkg/trait/route.go
@@ -102,7 +102,7 @@ func newRouteTrait() Trait {
 	}
 }
 
-// IsAllowedInProfile overrides default
+// IsAllowedInProfile overrides default.
 func (t *routeTrait) IsAllowedInProfile(profile v1.TraitProfile) bool {
 	return profile == v1.TraitProfileOpenShift
 }
diff --git a/pkg/trait/service.go b/pkg/trait/service.go
index 510a0bd..5590a35 100644
--- a/pkg/trait/service.go
+++ b/pkg/trait/service.go
@@ -31,7 +31,7 @@ import (
 //
 // It's enabled by default if the integration depends on a Camel component that can expose a HTTP endpoint.
 //
-// +camel-k:trait=service
+// +camel-k:trait=service.
 type serviceTrait struct {
 	BaseTrait `property:",squash"`
 	// To automatically detect from the code if a Service needs to be created.
@@ -48,7 +48,7 @@ func newServiceTrait() Trait {
 	}
 }
 
-// IsAllowedInProfile overrides default
+// IsAllowedInProfile overrides default.
 func (t *serviceTrait) IsAllowedInProfile(profile v1.TraitProfile) bool {
 	return profile == v1.TraitProfileKubernetes ||
 		profile == v1.TraitProfileOpenShift
diff --git a/pkg/trait/service_binding.go b/pkg/trait/service_binding.go
index 19a4e29..1b574f7 100644
--- a/pkg/trait/service_binding.go
+++ b/pkg/trait/service_binding.go
@@ -37,7 +37,7 @@ import (
 // The Service Binding trait allows users to connect to Services in Kubernetes:
 // https://github.com/k8s-service-bindings/spec#service-binding
 // As the specification is still evolving this is subject to change
-// +camel-k:trait=service-binding
+// +camel-k:trait=service-binding.
 type serviceBindingTrait struct {
 	BaseTrait `property:",squash"`
 	// List of Services in the form [[apigroup/]version:]kind:[namespace/]name
diff --git a/pkg/trait/toleration.go b/pkg/trait/toleration.go
index dc5c1cb..60f4dbf 100644
--- a/pkg/trait/toleration.go
+++ b/pkg/trait/toleration.go
@@ -38,7 +38,7 @@ import (
 //
 // It's disabled by default.
 //
-// +camel-k:trait=toleration
+// +camel-k:trait=toleration.
 type tolerationTrait struct {
 	BaseTrait `property:",squash"`
 	// The list of taints to tolerate, in the form `Key[=Value]:Effect[:Seconds]`
diff --git a/pkg/trait/trait.go b/pkg/trait/trait.go
index cbb3a9c..e0a308e 100644
--- a/pkg/trait/trait.go
+++ b/pkg/trait/trait.go
@@ -59,7 +59,7 @@ func Apply(ctx context.Context, c client.Client, integration *v1.Integration, ki
 	return environment, nil
 }
 
-// newEnvironment creates a Environment from the given data
+// newEnvironment creates a Environment from the given data.
 func newEnvironment(ctx context.Context, c client.Client, integration *v1.Integration, kit *v1.IntegrationKit) (*Environment, error) {
 	if integration == nil && ctx == nil {
 		return nil, errors.New("neither integration nor kit are set")
diff --git a/pkg/trait/trait_catalog.go b/pkg/trait/trait_catalog.go
index d5d1e97..d681592 100644
--- a/pkg/trait/trait_catalog.go
+++ b/pkg/trait/trait_catalog.go
@@ -30,13 +30,13 @@ import (
 	"github.com/apache/camel-k/pkg/util/log"
 )
 
-// Catalog collects all information about traits in one place
+// Catalog collects all information about traits in one place.
 type Catalog struct {
 	L      log.Logger
 	traits []Trait
 }
 
-// NewCatalog creates a new trait Catalog
+// NewCatalog creates a new trait Catalog.
 func NewCatalog(c client.Client) *Catalog {
 	traitList := make([]Trait, 0, len(FactoryList))
 	for _, factory := range FactoryList {
@@ -141,7 +141,7 @@ func (c *Catalog) apply(environment *Environment) error {
 	return nil
 }
 
-// GetTrait returns the trait with the given ID
+// GetTrait returns the trait with the given ID.
 func (c *Catalog) GetTrait(id string) Trait {
 	for _, t := range c.AllTraits() {
 		if t.ID() == ID(id) {
@@ -151,7 +151,7 @@ func (c *Catalog) GetTrait(id string) Trait {
 	return nil
 }
 
-// ComputeTraitsProperties returns all key/value configuration properties that can be used to configure traits
+// ComputeTraitsProperties returns all key/value configuration properties that can be used to configure traits.
 func (c *Catalog) ComputeTraitsProperties() []string {
 	results := make([]string, 0)
 	for _, trait := range c.AllTraits() {
diff --git a/pkg/trait/trait_factory.go b/pkg/trait/trait_factory.go
index f81e12a..5911ac5 100644
--- a/pkg/trait/trait_factory.go
+++ b/pkg/trait/trait_factory.go
@@ -17,13 +17,13 @@ limitations under the License.
 
 package trait
 
-// Factory is a generic factory for a trait
+// Factory is a generic factory for a trait.
 type Factory = func() Trait
 
-// FactoryList contains the default list of trait Factory
+// FactoryList contains the default list of trait Factory.
 var FactoryList []Factory
 
-// AddToTraits registers a trait Factory
+// AddToTraits registers a trait Factory.
 func AddToTraits(factory Factory) {
 	FactoryList = append(FactoryList, factory)
 }
diff --git a/pkg/trait/trait_types.go b/pkg/trait/trait_types.go
index 8c5a5d0..1757614 100644
--- a/pkg/trait/trait_types.go
+++ b/pkg/trait/trait_types.go
@@ -59,15 +59,15 @@ var (
 	serviceBindingsMountPath  = path.Join(confDPath, "_servicebindings")
 )
 
-// Identifiable represent an identifiable type
+// Identifiable represent an identifiable type.
 type Identifiable interface {
 	ID() ID
 }
 
-// ID uniquely identifies a trait
+// ID uniquely identifies a trait.
 type ID string
 
-// Trait is the interface of all traits
+// Trait is the interface of all traits.
 type Trait interface {
 	Identifiable
 	client.Injectable
@@ -103,7 +103,7 @@ type ComparableTrait interface {
 	Comparable
 }
 
-// A list of named orders, useful for correctly binding addons
+// A list of named orders, useful for correctly binding addons.
 const (
 	// TraitOrderBeforeControllerCreation can be used to inject configuration such as properties and environment variables
 	// into the running integration, before the actual controller is created.
@@ -124,7 +124,7 @@ func NewBaseTrait(id string, order int) BaseTrait {
 	}
 }
 
-// BaseTrait is the root trait with noop implementations for hooks
+// BaseTrait is the root trait with noop implementations for hooks.
 type BaseTrait struct {
 	TraitID ID `json:"-"`
 	// Can be used to enable or disable a trait. All traits share this common property.
@@ -134,17 +134,17 @@ type BaseTrait struct {
 	L              log.Logger    `json:"-"`
 }
 
-// ID returns the identifier of the trait
+// ID returns the identifier of the trait.
 func (trait *BaseTrait) ID() ID {
 	return trait.TraitID
 }
 
-// InjectClient implements client.ClientInject and allows to inject a client into the trait
+// InjectClient implements client.ClientInject and allows to inject a client into the trait.
 func (trait *BaseTrait) InjectClient(c client.Client) {
 	trait.Client = c
 }
 
-// InfluencesKit determines if the trait has any influence on Integration Kits
+// InfluencesKit determines if the trait has any influence on Integration Kits.
 func (trait *BaseTrait) InfluencesKit() bool {
 	return false
 }
@@ -154,18 +154,18 @@ func (trait *BaseTrait) IsPlatformTrait() bool {
 	return false
 }
 
-// RequiresIntegrationPlatform indicates that the trait cannot work without an integration platform set
+// RequiresIntegrationPlatform indicates that the trait cannot work without an integration platform set.
 func (trait *BaseTrait) RequiresIntegrationPlatform() bool {
 	// All traits require a platform by default
 	return true
 }
 
-// IsAllowedInProfile returns true for any profile by default
+// IsAllowedInProfile returns true for any profile by default.
 func (trait *BaseTrait) IsAllowedInProfile(v1.TraitProfile) bool {
 	return true
 }
 
-// Order contains the order value provided during initialization
+// Order contains the order value provided during initialization.
 func (trait *BaseTrait) Order() int {
 	return trait.ExecutionOrder
 }
@@ -178,7 +178,7 @@ type ControllerStrategySelector interface {
 	ControllerStrategySelectorOrder() int
 }
 
-// An Environment provides the context for the execution of the traits
+// An Environment provides the context for the execution of the traits.
 type Environment struct {
 	CamelCatalog   *camel.RuntimeCatalog
 	RuntimeVersion string
@@ -209,10 +209,10 @@ type Environment struct {
 	ServiceBindingSecret  string
 }
 
-// ControllerStrategy is used to determine the kind of controller that needs to be created for the integration
+// ControllerStrategy is used to determine the kind of controller that needs to be created for the integration.
 type ControllerStrategy string
 
-// List of controller strategies
+// List of controller strategies.
 const (
 	ControllerStrategyDeployment     ControllerStrategy = "deployment"
 	ControllerStrategyKnativeService ControllerStrategy = "knative-service"
@@ -270,7 +270,7 @@ func (e *Environment) InPhase(c v1.IntegrationKitPhase, i v1.IntegrationPhase) b
 // DetermineProfile determines the TraitProfile of the environment.
 // First looking at the Integration.Spec for a Profile,
 // next looking at the IntegrationKit.Spec
-// and lastly the Platform Profile
+// and lastly the Platform Profile.
 func (e *Environment) DetermineProfile() v1.TraitProfile {
 	if e.Integration != nil {
 		if e.Integration.Status.Profile != "" {
@@ -292,7 +292,7 @@ func (e *Environment) DetermineProfile() v1.TraitProfile {
 	return v1.DefaultTraitProfile
 }
 
-// DetermineControllerStrategy determines the type of controller that should be used for the integration
+// DetermineControllerStrategy determines the type of controller that should be used for the integration.
 func (e *Environment) DetermineControllerStrategy() (ControllerStrategy, error) {
 	defaultStrategy := DefaultControllerStrategy
 	for _, creator := range e.getControllerStrategyChoosers() {
@@ -318,7 +318,7 @@ func (e *Environment) getControllerStrategyChoosers() (res []ControllerStrategyS
 	return res
 }
 
-// GetIntegrationPodSpec return the Integration Template Pod Specification, regardless of the deployment strategy
+// GetIntegrationPodSpec return the Integration Template Pod Specification, regardless of the deployment strategy.
 func (e *Environment) GetIntegrationPodSpec() *corev1.PodSpec {
 	// Deployment
 	deployment := e.Resources.GetDeployment(func(d *appsv1.Deployment) bool {
diff --git a/pkg/trait/util.go b/pkg/trait/util.go
index d6f7b9a..e4e7e12 100644
--- a/pkg/trait/util.go
+++ b/pkg/trait/util.go
@@ -40,7 +40,7 @@ import (
 
 var exactVersionRegexp = regexp.MustCompile(`^(\d+)\.(\d+)\.([\w-.]+)$`)
 
-// getIntegrationKit retrieves the kit set on the integration
+// getIntegrationKit retrieves the kit set on the integration.
 func getIntegrationKit(ctx context.Context, c client.Client, integration *v1.Integration) (*v1.IntegrationKit, error) {
 	if integration.Status.IntegrationKit == nil {
 		return nil, nil
@@ -223,12 +223,12 @@ func AddSourceDependencies(source v1.SourceSpec, catalog *camel.RuntimeCatalog)
 
 // Bool pointer operations:
 
-// BoolP returns a pointer to a bool value
+// BoolP returns a pointer to a bool value.
 func BoolP(b bool) *bool {
 	return &b
 }
 
-// IsTrue checks if the bool pointer is defined and true
+// IsTrue checks if the bool pointer is defined and true.
 func IsTrue(b *bool) bool {
 	return b != nil && *b
 }
@@ -239,7 +239,7 @@ func IsNilOrTrue(b *bool) bool {
 	return b == nil || *b
 }
 
-// IsFalse checks if the bool pointer is defined and false
+// IsFalse checks if the bool pointer is defined and false.
 func IsFalse(b *bool) bool {
 	return b != nil && !*b
 }
diff --git a/pkg/util/bindings/api.go b/pkg/util/bindings/api.go
index c844d1e..ea98f88 100644
--- a/pkg/util/bindings/api.go
+++ b/pkg/util/bindings/api.go
@@ -33,7 +33,7 @@ const (
 	OrderLast     = 100
 )
 
-// Binding represents how a Kubernetes object is represented in Camel K resources
+// Binding represents how a Kubernetes object is represented in Camel K resources.
 type Binding struct {
 	// URI is the Camel URI equivalent
 	URI string
@@ -45,7 +45,7 @@ type Binding struct {
 	ApplicationProperties map[string]string
 }
 
-// BindingProvider maps a KameletBinding endpoint into Camel K resources
+// BindingProvider maps a KameletBinding endpoint into Camel K resources.
 type BindingProvider interface {
 	// ID returns the name of the binding provider
 	ID() string
diff --git a/pkg/util/bindings/catalog.go b/pkg/util/bindings/catalog.go
index b12b504..dd2e87f 100644
--- a/pkg/util/bindings/catalog.go
+++ b/pkg/util/bindings/catalog.go
@@ -36,7 +36,7 @@ func RegisterBindingProvider(bp BindingProvider) {
 	})
 }
 
-// Translate execute all chained binding providers, returning the first success or the first error
+// Translate execute all chained binding providers, returning the first success or the first error.
 func Translate(ctx BindingContext, endpointCtx EndpointContext, endpoint v1alpha1.Endpoint) (*Binding, error) {
 	if err := validateEndpoint(ctx, endpoint); err != nil {
 		return nil, err
diff --git a/pkg/util/bindings/kamelet.go b/pkg/util/bindings/kamelet.go
index d52f144..464bbe5 100644
--- a/pkg/util/bindings/kamelet.go
+++ b/pkg/util/bindings/kamelet.go
@@ -25,7 +25,7 @@ import (
 	"k8s.io/apimachinery/pkg/runtime/schema"
 )
 
-// KameletBindingProvider converts a reference to a Kamelet into a Camel URI
+// KameletBindingProvider converts a reference to a Kamelet into a Camel URI.
 type KameletBindingProvider struct{}
 
 func (k KameletBindingProvider) ID() string {
diff --git a/pkg/util/camel/camel_dependencies.go b/pkg/util/camel/camel_dependencies.go
index 39cc336..9ecdf62 100644
--- a/pkg/util/camel/camel_dependencies.go
+++ b/pkg/util/camel/camel_dependencies.go
@@ -27,7 +27,7 @@ import (
 	"github.com/rs/xid"
 )
 
-// ManageIntegrationDependencies --
+// ManageIntegrationDependencies --.
 func ManageIntegrationDependencies(
 	project *maven.Project,
 	dependencies []string,
@@ -185,7 +185,7 @@ func postProcessDependencies(project *maven.Project, catalog *RuntimeCatalog) {
 	}
 }
 
-// SanitizeIntegrationDependencies --
+// SanitizeIntegrationDependencies --.
 func SanitizeIntegrationDependencies(dependencies []maven.Dependency) error {
 	for i := 0; i < len(dependencies); i++ {
 		dep := dependencies[i]
diff --git a/pkg/util/camel/camel_runtime.go b/pkg/util/camel/camel_runtime.go
index 2bd59d0..9c22dae 100644
--- a/pkg/util/camel/camel_runtime.go
+++ b/pkg/util/camel/camel_runtime.go
@@ -26,7 +26,7 @@ import (
 	"github.com/apache/camel-k/pkg/client"
 )
 
-// LoadCatalog --
+// LoadCatalog --.
 func LoadCatalog(ctx context.Context, client client.Client, namespace string, runtime v1.RuntimeSpec) (*RuntimeCatalog, error) {
 	options := []k8sclient.ListOption{
 		k8sclient.InNamespace(namespace),
diff --git a/pkg/util/camel/camel_runtime_catalog.go b/pkg/util/camel/camel_runtime_catalog.go
index e726685..787370a 100644
--- a/pkg/util/camel/camel_runtime_catalog.go
+++ b/pkg/util/camel/camel_runtime_catalog.go
@@ -23,7 +23,7 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// NewRuntimeCatalog --
+// NewRuntimeCatalog --.
 func NewRuntimeCatalog(spec v1.CamelCatalogSpec) *RuntimeCatalog {
 	catalog := RuntimeCatalog{}
 	catalog.CamelCatalogSpec = spec
@@ -69,7 +69,7 @@ func NewRuntimeCatalog(spec v1.CamelCatalogSpec) *RuntimeCatalog {
 	return &catalog
 }
 
-// RuntimeCatalog --
+// RuntimeCatalog --.
 type RuntimeCatalog struct {
 	v1.CamelCatalogSpec
 
@@ -80,7 +80,7 @@ type RuntimeCatalog struct {
 	javaTypeDependencies map[string]string
 }
 
-// HasArtifact --
+// HasArtifact --.
 func (c *RuntimeCatalog) HasArtifact(artifact string) bool {
 	if !strings.HasPrefix(artifact, "camel-") {
 		artifact = "camel-" + artifact
@@ -91,7 +91,7 @@ func (c *RuntimeCatalog) HasArtifact(artifact string) bool {
 	return ok
 }
 
-// GetArtifactByScheme returns the artifact corresponding to the given component scheme
+// GetArtifactByScheme returns the artifact corresponding to the given component scheme.
 func (c *RuntimeCatalog) GetArtifactByScheme(scheme string) *v1.CamelArtifact {
 	if id, ok := c.artifactByScheme[scheme]; ok {
 		if artifact, present := c.Artifacts[id]; present {
@@ -101,7 +101,7 @@ func (c *RuntimeCatalog) GetArtifactByScheme(scheme string) *v1.CamelArtifact {
 	return nil
 }
 
-// GetArtifactByDataFormat returns the artifact corresponding to the given data format
+// GetArtifactByDataFormat returns the artifact corresponding to the given data format.
 func (c *RuntimeCatalog) GetArtifactByDataFormat(dataFormat string) *v1.CamelArtifact {
 	if id, ok := c.artifactByDataFormat[dataFormat]; ok {
 		if artifact, present := c.Artifacts[id]; present {
@@ -111,25 +111,25 @@ func (c *RuntimeCatalog) GetArtifactByDataFormat(dataFormat string) *v1.CamelArt
 	return nil
 }
 
-// GetScheme returns the scheme definition for the given scheme id
+// GetScheme returns the scheme definition for the given scheme id.
 func (c *RuntimeCatalog) GetScheme(id string) (v1.CamelScheme, bool) {
 	scheme, ok := c.schemesByID[id]
 	return scheme, ok
 }
 
-// GetLanguageDependency returns the maven dependency for the given language name
+// GetLanguageDependency returns the maven dependency for the given language name.
 func (c *RuntimeCatalog) GetLanguageDependency(language string) (string, bool) {
 	language, ok := c.languageDependencies[language]
 	return language, ok
 }
 
-// GetJavaTypeDependency returns the maven dependency for the given type name
+// GetJavaTypeDependency returns the maven dependency for the given type name.
 func (c *RuntimeCatalog) GetJavaTypeDependency(camelType string) (string, bool) {
 	javaType, ok := c.javaTypeDependencies[camelType]
 	return javaType, ok
 }
 
-// VisitArtifacts --
+// VisitArtifacts --.
 func (c *RuntimeCatalog) VisitArtifacts(visitor func(string, v1.CamelArtifact) bool) {
 	for id, artifact := range c.Artifacts {
 		if !visitor(id, artifact) {
@@ -138,7 +138,7 @@ func (c *RuntimeCatalog) VisitArtifacts(visitor func(string, v1.CamelArtifact) b
 	}
 }
 
-// VisitSchemes --
+// VisitSchemes --.
 func (c *RuntimeCatalog) VisitSchemes(visitor func(string, v1.CamelScheme) bool) {
 	for id, scheme := range c.schemesByID {
 		if !visitor(id, scheme) {
@@ -147,7 +147,7 @@ func (c *RuntimeCatalog) VisitSchemes(visitor func(string, v1.CamelScheme) bool)
 	}
 }
 
-// DecodeComponent parses an URI and return a camel artifact and a scheme
+// DecodeComponent parses an URI and return a camel artifact and a scheme.
 func (c *RuntimeCatalog) DecodeComponent(uri string) (*v1.CamelArtifact, *v1.CamelScheme) {
 	uriSplit := strings.SplitN(uri, ":", 2)
 	if len(uriSplit) < 2 {
diff --git a/pkg/util/camel/camel_types.go b/pkg/util/camel/camel_types.go
index 7dd776a..fb0028d 100644
--- a/pkg/util/camel/camel_types.go
+++ b/pkg/util/camel/camel_types.go
@@ -22,13 +22,13 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// CatalogVersion --
+// CatalogVersion --.
 type CatalogVersion struct {
 	RuntimeVersion *semver.Version
 	Catalog        *v1.CamelCatalog
 }
 
-// CatalogVersionCollection --
+// CatalogVersionCollection --.
 type CatalogVersionCollection []CatalogVersion
 
 // Len returns the length of a collection. The number of CatalogVersion instances
diff --git a/pkg/util/cancellable/cancellable.go b/pkg/util/cancellable/cancellable.go
index 3e90d31..47e0c98 100644
--- a/pkg/util/cancellable/cancellable.go
+++ b/pkg/util/cancellable/cancellable.go
@@ -19,19 +19,19 @@ package cancellable
 
 import "context"
 
-// Context --
+// A Context with cancellation trait.
 type Context interface {
 	context.Context
 
 	Cancel()
 }
 
-// NewContext --
+// NewContext returns an empty cancelable Context.
 func NewContext() Context {
 	return NewContextWithParent(context.TODO())
 }
 
-// NewContextWithParent --
+// NewContextWithParent returns an empty cancelable Context with a parent.
 func NewContextWithParent(parent context.Context) Context {
 	c, cc := context.WithCancel(parent)
 
diff --git a/pkg/util/digest/digest.go b/pkg/util/digest/digest.go
index 1e62e02..4d999a1 100644
--- a/pkg/util/digest/digest.go
+++ b/pkg/util/digest/digest.go
@@ -38,7 +38,7 @@ import (
 )
 
 // ComputeForIntegration a digest of the fields that are relevant for the deployment
-// Produces a digest that can be used as docker image tag
+// Produces a digest that can be used as docker image tag.
 func ComputeForIntegration(integration *v1.Integration) (string, error) {
 	hash := sha256.New()
 	// Integration version is relevant
@@ -135,7 +135,7 @@ func ComputeForIntegration(integration *v1.Integration) (string, error) {
 }
 
 // ComputeForIntegrationKit a digest of the fields that are relevant for the deployment
-// Produces a digest that can be used as docker image tag
+// Produces a digest that can be used as docker image tag.
 func ComputeForIntegrationKit(kit *v1.IntegrationKit) (string, error) {
 	hash := sha256.New()
 	// Kit version is relevant
@@ -159,7 +159,7 @@ func ComputeForIntegrationKit(kit *v1.IntegrationKit) (string, error) {
 	return digest, nil
 }
 
-// ComputeForResource returns a digest for the specific resource
+// ComputeForResource returns a digest for the specific resource.
 func ComputeForResource(res v1.ResourceSpec) (string, error) {
 	hash := sha256.New()
 	// Operator version is relevant
@@ -194,7 +194,7 @@ func ComputeForResource(res v1.ResourceSpec) (string, error) {
 	return digest, nil
 }
 
-// ComputeForSource returns a digest for the specific source
+// ComputeForSource returns a digest for the specific source.
 func ComputeForSource(s v1.SourceSpec) (string, error) {
 	hash := sha256.New()
 	// Operator version is relevant
diff --git a/pkg/util/docker/docker.go b/pkg/util/docker/docker.go
index d94da3c..38bf8a0 100644
--- a/pkg/util/docker/docker.go
+++ b/pkg/util/docker/docker.go
@@ -27,7 +27,7 @@ import (
 	"github.com/pkg/errors"
 )
 
-// CreateBaseImageDockerFile --
+// CreateBaseImageDockerFile --.
 func CreateBaseImageDockerFile() error {
 	dockerFile := []string{}
 
@@ -47,7 +47,7 @@ func CreateBaseImageDockerFile() error {
 	return nil
 }
 
-// CreateIntegrationImageDockerFile --
+// CreateIntegrationImageDockerFile --.
 func CreateIntegrationImageDockerFile(integrationRunCmd *exec.Cmd, startsFromLocalFolder bool) error {
 	dockerFile := []string{}
 
@@ -92,7 +92,7 @@ func CreateIntegrationImageDockerFile(integrationRunCmd *exec.Cmd, startsFromLoc
 	return nil
 }
 
-// BuildBaseImageArgs --
+// BuildBaseImageArgs --.
 func BuildBaseImageArgs() []string {
 	// Construct the docker command:
 	//
@@ -102,7 +102,7 @@ func BuildBaseImageArgs() []string {
 	return BuildImageArgs(BaseWorkingDirectory, GetBaseImagePath(), BaseWorkingDirectory)
 }
 
-// BuildIntegrationImageArgs --
+// BuildIntegrationImageArgs --.
 func BuildIntegrationImageArgs(imagePath string) []string {
 	// Construct the docker command:
 	//
@@ -111,7 +111,7 @@ func BuildIntegrationImageArgs(imagePath string) []string {
 	return BuildImageArgs(IntegrationWorkingDirectory, imagePath, util.MavenWorkingDirectory)
 }
 
-// RunIntegrationImageArgs --
+// RunIntegrationImageArgs --.
 func RunIntegrationImageArgs(imagePath string) ([]string, error) {
 	// Construct the docker command:
 	//
@@ -150,7 +150,7 @@ func ContainerizeFilePaths(currentFilePaths []string, newDir string) []string {
 	return newFilePaths
 }
 
-// ContainerizeDependencyPaths -- make dependency paths valid given a valid container directory in newDir
+// ContainerizeDependencyPaths -- make dependency paths valid given a valid container directory in newDir.
 func ContainerizeDependencyPaths(dependencyPaths []string, newDir string) []string {
 	newDependencyPaths := []string{}
 	for _, currentDependencyPath := range dependencyPaths {
diff --git a/pkg/util/docker/docker_base.go b/pkg/util/docker/docker_base.go
index e4d98c8..b1e032f 100644
--- a/pkg/util/docker/docker_base.go
+++ b/pkg/util/docker/docker_base.go
@@ -99,7 +99,7 @@ func RunImageArgs(imagePath string, imageTag string) ([]string, error) {
 // Arguments to docker command line.
 //
 
-// DockerfilePathArg --
+// DockerfilePathArg --.
 func DockerfilePathArg(dockerfilePath string) []string {
 	args := make([]string, 0)
 	args = append(args, "-f")
@@ -107,7 +107,7 @@ func DockerfilePathArg(dockerfilePath string) []string {
 	return args
 }
 
-// ImageArg --
+// ImageArg --.
 func ImageArg(dockerImageName string, tag string) []string {
 	args := make([]string, 0)
 	args = append(args, "-t")
@@ -115,7 +115,7 @@ func ImageArg(dockerImageName string, tag string) []string {
 	return args
 }
 
-// LatestImageArg --
+// LatestImageArg --.
 func LatestImageArg(dockerImageName string) []string {
 	args := make([]string, 0)
 	args = append(args, "-t")
@@ -123,7 +123,7 @@ func LatestImageArg(dockerImageName string) []string {
 	return args
 }
 
-// FullImageArg --
+// FullImageArg --.
 func FullImageArg(dockerImage string) []string {
 	imageComponents := strings.Split(dockerImage, ":")
 	if len(imageComponents) == 2 {
@@ -147,7 +147,7 @@ func FullImageArg(dockerImage string) []string {
 // Docker-spcific helper functions.
 //
 
-// GetImage - <image-name>:<tag>
+// GetImage - <image-name>:<tag>.
 func GetImage(dockerImageName string, tag string) string {
 	image := make([]string, 0)
 	image = append(image, dockerImageName)
@@ -155,12 +155,12 @@ func GetImage(dockerImageName string, tag string) string {
 	return strings.Join(image, ":")
 }
 
-// GetLatestImage - <image-name>:latest
+// GetLatestImage - <image-name>:latest.
 func GetLatestImage(dockerImageName string) string {
 	return GetImage(dockerImageName, latestTag)
 }
 
-// GetFullDockerImage - <docker-registry>/<image-name>:<tag>
+// GetFullDockerImage - <docker-registry>/<image-name>:<tag>.
 func GetFullDockerImage(dockerImageName string, tag string) string {
 	fullImagePath := make([]string, 0)
 
@@ -174,7 +174,7 @@ func GetFullDockerImage(dockerImageName string, tag string) string {
 	return strings.Join(fullImagePath, dockerEndpointSeparator)
 }
 
-// GetBaseImagePath --
+// GetBaseImagePath --.
 func GetBaseImagePath() string {
 	return RegistryName + dockerEndpointSeparator + BaseImageName
 }
@@ -195,67 +195,67 @@ func JoinPath(lhsPath string, rhsPath string) string {
 
 // Generic commands.
 
-// COPY --
+// COPY --.
 func COPY(from string, to string) string {
 	c := []string{"COPY", from, to}
 	return strings.Join(c, " ")
 }
 
-// RUN --
+// RUN --.
 func RUN(command string) string {
 	c := []string{"RUN", command}
 	return strings.Join(c, " ")
 }
 
-// FROM --
+// FROM --.
 func FROM(imageName string) string {
 	c := []string{"FROM", imageName}
 	return strings.Join(c, " ")
 }
 
-// WORKDIR --
+// WORKDIR --.
 func WORKDIR(workDir string) string {
 	c := []string{"WORKDIR", workDir}
 	return strings.Join(c, " ")
 }
 
-// ENV --
+// ENV --.
 func ENV(envVar string, value string) string {
 	p := []string{envVar, value}
 	c := []string{"ENV", strings.Join(p, "=")}
 	return strings.Join(c, " ")
 }
 
-// AS --
+// AS --.
 func AS(image string, alias string) string {
 	c := []string{image, "as", alias}
 	return strings.Join(c, " ")
 }
 
-// CMD --
+// CMD --.
 func CMD(command string) string {
 	c := []string{"CMD", command}
 	return strings.Join(c, " ")
 }
 
-// RUNMavenInstall --
+// RUNMavenInstall --.
 func RUNMavenInstall() string {
 	return RUN("apt-get update && apt-get install maven -y && apt-get upgrade -y")
 }
 
-// RUNMakeDir --
+// RUNMakeDir --.
 func RUNMakeDir(dirName string) string {
 	c := []string{"mkdir", "-p", dirName}
 	return RUN(strings.Join(c, " "))
 }
 
-// ENVAppend --
+// ENVAppend --.
 func ENVAppend(envVar string, value string) string {
 	tail := []string{value, "$" + envVar}
 	return ENV(envVar, strings.Join(tail, ":"))
 }
 
-// CMDShellWrap --
+// CMDShellWrap --.
 func CMDShellWrap(command string) string {
 	return CMD("/bin/sh -c \"" + command + "\"")
 }
diff --git a/pkg/util/dsl/flow.go b/pkg/util/dsl/flow.go
index 7044005..6093bea 100644
--- a/pkg/util/dsl/flow.go
+++ b/pkg/util/dsl/flow.go
@@ -31,12 +31,12 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// FromYamlDSLString creates a slice of flows from a Camel YAML DSL string
+// FromYamlDSLString creates a slice of flows from a Camel YAML DSL string.
 func FromYamlDSLString(flowsString string) ([]v1.Flow, error) {
 	return FromYamlDSL(bytes.NewReader([]byte(flowsString)))
 }
 
-// FromYamlDSL creates a slice of flows from a Camel YAML DSL stream
+// FromYamlDSL creates a slice of flows from a Camel YAML DSL stream.
 func FromYamlDSL(reader io.Reader) ([]v1.Flow, error) {
 	buffered, err := ioutil.ReadAll(reader)
 	if err != nil {
@@ -56,7 +56,7 @@ func FromYamlDSL(reader io.Reader) ([]v1.Flow, error) {
 	return flows, err
 }
 
-// ToYamlDSL converts a flow into its Camel YAML DSL equivalent
+// ToYamlDSL converts a flow into its Camel YAML DSL equivalent.
 func ToYamlDSL(flows []v1.Flow) ([]byte, error) {
 	data, err := json.Marshal(&flows)
 	if err != nil {
diff --git a/pkg/util/dsl/template.go b/pkg/util/dsl/template.go
index d63b4d3..5f83ca3 100644
--- a/pkg/util/dsl/template.go
+++ b/pkg/util/dsl/template.go
@@ -26,7 +26,7 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// TemplateToYamlDSL converts a kamelet template into its Camel YAML DSL equivalent
+// TemplateToYamlDSL converts a kamelet template into its Camel YAML DSL equivalent.
 func TemplateToYamlDSL(template v1.Template, id string) ([]byte, error) {
 	data, err := json.Marshal(&template)
 	if err != nil {
diff --git a/pkg/util/envvar/envvar.go b/pkg/util/envvar/envvar.go
index 65ada3b..f22cee8 100644
--- a/pkg/util/envvar/envvar.go
+++ b/pkg/util/envvar/envvar.go
@@ -19,7 +19,7 @@ package envvar
 
 import corev1 "k8s.io/api/core/v1"
 
-// Get --
+// Get --.
 func Get(vars []corev1.EnvVar, name string) *corev1.EnvVar {
 	for i := 0; i < len(vars); i++ {
 		if vars[i].Name == name {
@@ -30,7 +30,7 @@ func Get(vars []corev1.EnvVar, name string) *corev1.EnvVar {
 	return nil
 }
 
-// Remove --
+// Remove --.
 func Remove(vars *[]corev1.EnvVar, name string) {
 	v := *vars
 	for i := 0; i < len(v); i++ {
@@ -42,7 +42,7 @@ func Remove(vars *[]corev1.EnvVar, name string) {
 	}
 }
 
-// SetVal --
+// SetVal --.
 func SetVal(vars *[]corev1.EnvVar, name string, value string) {
 	if envVar := Get(*vars, name); envVar != nil {
 		envVar.Value = value
@@ -55,7 +55,7 @@ func SetVal(vars *[]corev1.EnvVar, name string, value string) {
 	}
 }
 
-// SetVar --
+// SetVar --.
 func SetVar(vars *[]corev1.EnvVar, newEnvVar corev1.EnvVar) {
 	envVar := Get(*vars, newEnvVar.Name)
 
@@ -72,7 +72,7 @@ func SetVar(vars *[]corev1.EnvVar, newEnvVar corev1.EnvVar) {
 	}
 }
 
-// SetValFrom --
+// SetValFrom --.
 func SetValFrom(vars *[]corev1.EnvVar, name string, path string) {
 	if envVar := Get(*vars, name); envVar != nil {
 		envVar.Value = ""
diff --git a/pkg/util/gzip/compress.go b/pkg/util/gzip/compress.go
index ede1ff2..62201fa 100644
--- a/pkg/util/gzip/compress.go
+++ b/pkg/util/gzip/compress.go
@@ -25,7 +25,7 @@ import (
 	"io/ioutil"
 )
 
-// Compress --
+// Compress --.
 func Compress(buffer io.Writer, data []byte) error {
 	gz := g.NewWriter(buffer)
 
@@ -42,7 +42,7 @@ func Compress(buffer io.Writer, data []byte) error {
 	return nil
 }
 
-// CompressBase64 --
+// CompressBase64 --.
 func CompressBase64(data []byte) ([]byte, error) {
 	var b bytes.Buffer
 
@@ -53,7 +53,7 @@ func CompressBase64(data []byte) ([]byte, error) {
 	return []byte(base64.StdEncoding.EncodeToString(b.Bytes())), nil
 }
 
-// Uncompress --
+// Uncompress --.
 func Uncompress(buffer io.Writer, data []byte) error {
 	b := bytes.NewBuffer(data)
 	gz, err := g.NewReader(b)
@@ -76,7 +76,7 @@ func Uncompress(buffer io.Writer, data []byte) error {
 	return nil
 }
 
-// UncompressBase64 --
+// UncompressBase64 --.
 func UncompressBase64(data []byte) ([]byte, error) {
 	d, err := base64.StdEncoding.DecodeString(string(data))
 	if err != nil {
diff --git a/pkg/util/indentedwriter/writer.go b/pkg/util/indentedwriter/writer.go
index 2ba8994..97fe37f 100644
--- a/pkg/util/indentedwriter/writer.go
+++ b/pkg/util/indentedwriter/writer.go
@@ -25,7 +25,7 @@ import (
 	"text/tabwriter"
 )
 
-// Flusher --
+// Flusher --.
 type Flusher interface {
 	Flush()
 }
@@ -35,32 +35,32 @@ type Writer struct {
 	out io.Writer
 }
 
-// NewWriter --
+// NewWriter --.
 func NewWriter(out io.Writer) *Writer {
 	return &Writer{out: out}
 }
 
-// Writef --
+// Writef --.
 func (iw *Writer) Writef(indentLevel int, format string, i ...interface{}) {
 	fmt.Fprint(iw.out, strings.Repeat("  ", indentLevel))
 	fmt.Fprintf(iw.out, format, i...)
 }
 
-// Writelnf --
+// Writelnf --.
 func (iw *Writer) Writelnf(indentLevel int, format string, i ...interface{}) {
 	fmt.Fprint(iw.out, strings.Repeat("  ", indentLevel))
 	fmt.Fprintf(iw.out, format, i...)
 	fmt.Fprint(iw.out, "\n")
 }
 
-// Flush --
+// Flush --.
 func (iw *Writer) Flush() {
 	if f, ok := iw.out.(Flusher); ok {
 		f.Flush()
 	}
 }
 
-// IndentedString --
+// IndentedString --.
 func IndentedString(f func(io.Writer) error) (string, error) {
 	var out tabwriter.Writer
 	buf := &bytes.Buffer{}
diff --git a/pkg/util/knative/apis.go b/pkg/util/knative/apis.go
index 67bf5b2..2dffb8f 100644
--- a/pkg/util/knative/apis.go
+++ b/pkg/util/knative/apis.go
@@ -25,7 +25,7 @@ import (
 )
 
 var (
-	// KnownChannelKinds are known channel kinds belonging to Knative
+	// KnownChannelKinds are known channel kinds belonging to Knative.
 	KnownChannelKinds = []GroupVersionKindResource{
 		{
 			GroupVersionKind: schema.GroupVersionKind{
@@ -85,7 +85,7 @@ var (
 		},
 	}
 
-	// KnownEndpointKinds are known endpoint kinds belonging to Knative
+	// KnownEndpointKinds are known endpoint kinds belonging to Knative.
 	KnownEndpointKinds = []GroupVersionKindResource{
 		{
 			GroupVersionKind: schema.GroupVersionKind{
@@ -113,7 +113,7 @@ var (
 		},
 	}
 
-	// KnownBrokerKinds are known broker kinds belonging to Knative
+	// KnownBrokerKinds are known broker kinds belonging to Knative.
 	KnownBrokerKinds = []GroupVersionKindResource{
 		{
 			GroupVersionKind: schema.GroupVersionKind{
@@ -134,7 +134,7 @@ var (
 	}
 
 	// RequiredKinds are Knative kinds used by Camel K for materializing integrations.
-	// They must be present on the cluster
+	// They must be present on the cluster.
 	RequiredKinds = []GroupVersionKindResource{
 		{
 			GroupVersionKind: schema.GroupVersionKind{
@@ -147,7 +147,7 @@ var (
 	}
 )
 
-// GroupVersionKindResource --
+// GroupVersionKindResource --.
 type GroupVersionKindResource struct {
 	schema.GroupVersionKind
 	Resource string
diff --git a/pkg/util/knative/knative.go b/pkg/util/knative/knative.go
index 03f9f00..9a1d225 100644
--- a/pkg/util/knative/knative.go
+++ b/pkg/util/knative/knative.go
@@ -141,7 +141,7 @@ func CreateSinkBinding(source corev1.ObjectReference, target corev1.ObjectRefere
 	}
 }
 
-// GetAddressableReference looks up the resource among all given types and returns an object reference to it
+// GetAddressableReference looks up the resource among all given types and returns an object reference to it.
 func GetAddressableReference(ctx context.Context, c client.Client,
 	possibleReferences []corev1.ObjectReference, namespace string, name string) (*corev1.ObjectReference, error) {
 
@@ -160,7 +160,7 @@ func GetAddressableReference(ctx context.Context, c client.Client,
 	return nil, k8serrors.NewNotFound(schema.GroupResource{}, name)
 }
 
-// GetSinkURL returns the sink as *url.URL
+// GetSinkURL returns the sink as *url.URL.
 func GetSinkURL(ctx context.Context, c client.Client, sink *corev1.ObjectReference, namespace string) (*url.URL, error) {
 	res, err := getSinkURI(ctx, c, sink, namespace)
 	if err != nil {
diff --git a/pkg/util/knative/uri.go b/pkg/util/knative/uri.go
index 063975e..8fca880 100644
--- a/pkg/util/knative/uri.go
+++ b/pkg/util/knative/uri.go
@@ -37,7 +37,7 @@ const (
 	paramBrokerName = "name"
 )
 
-// FilterURIs returns all Knative URIs of the given type from a slice
+// FilterURIs returns all Knative URIs of the given type from a slice.
 func FilterURIs(uris []string, kind knativev1.CamelServiceType) []string {
 	res := make([]string, 0)
 	for _, uri := range uris {
@@ -48,7 +48,7 @@ func FilterURIs(uris []string, kind knativev1.CamelServiceType) []string {
 	return res
 }
 
-// NormalizeToURI produces a Knative uri of the given service type if the argument is a plain string
+// NormalizeToURI produces a Knative uri of the given service type if the argument is a plain string.
 func NormalizeToURI(kind knativev1.CamelServiceType, uriOrString string) string {
 	if plainNameRegexp.MatchString(uriOrString) {
 		return fmt.Sprintf("knative://%s/%s", string(kind), uriOrString)
@@ -56,7 +56,7 @@ func NormalizeToURI(kind knativev1.CamelServiceType, uriOrString string) string
 	return uriOrString
 }
 
-// ExtractObjectReference returns a reference to the object described in the Knative URI
+// ExtractObjectReference returns a reference to the object described in the Knative URI.
 func ExtractObjectReference(uri string) (v1.ObjectReference, error) {
 	if isKnativeURI(knativev1.CamelServiceTypeEvent, uri) {
 		name := uriutils.GetQueryParameter(uri, paramBrokerName)
@@ -83,7 +83,7 @@ func ExtractObjectReference(uri string) (v1.ObjectReference, error) {
 	}, nil
 }
 
-// ExtractEventType extract the eventType from a event URI
+// ExtractEventType extract the eventType from a event URI.
 func ExtractEventType(uri string) string {
 	return matchOrEmpty(uriRegexp, 2, uri)
 }
diff --git a/pkg/util/kubernetes/camel.go b/pkg/util/kubernetes/camel.go
index 5cc7e1e..f0b7404 100644
--- a/pkg/util/kubernetes/camel.go
+++ b/pkg/util/kubernetes/camel.go
@@ -36,7 +36,7 @@ const (
 	CamelCreatorLabelVersion   = CamelCreatorLabelPrefix + ".version"
 )
 
-// FilterCamelCreatorLabels is used to inherit the creator information among resources
+// FilterCamelCreatorLabels is used to inherit the creator information among resources.
 func FilterCamelCreatorLabels(source map[string]string) map[string]string {
 	res := make(map[string]string)
 	for k, v := range source {
@@ -47,7 +47,7 @@ func FilterCamelCreatorLabels(source map[string]string) map[string]string {
 	return res
 }
 
-// MergeCamelCreatorLabels is used to inject the creator information from another set of labels
+// MergeCamelCreatorLabels is used to inject the creator information from another set of labels.
 func MergeCamelCreatorLabels(source map[string]string, target map[string]string) map[string]string {
 	if target == nil {
 		target = make(map[string]string)
@@ -58,7 +58,7 @@ func MergeCamelCreatorLabels(source map[string]string, target map[string]string)
 	return target
 }
 
-// GetCamelCreator returns the Camel creator object referenced by this runtime object, if present
+// GetCamelCreator returns the Camel creator object referenced by this runtime object, if present.
 func GetCamelCreator(obj runtime.Object) *corev1.ObjectReference {
 	if m, ok := obj.(metav1.Object); ok {
 		kind := m.GetLabels()[CamelCreatorLabelKind]
diff --git a/pkg/util/kubernetes/client.go b/pkg/util/kubernetes/client.go
index bb8514e..3b361e4 100644
--- a/pkg/util/kubernetes/client.go
+++ b/pkg/util/kubernetes/client.go
@@ -96,7 +96,7 @@ func GetSecret(context context.Context, client ctrl.Reader, name string, namespa
 	return secret, nil
 }
 
-// GetSecretRefValue returns the value of a secret in the supplied namespace
+// GetSecretRefValue returns the value of a secret in the supplied namespace.
 func GetSecretRefValue(ctx context.Context, client ctrl.Reader, namespace string, selector *corev1.SecretKeySelector) (string, error) {
 	data, err := GetSecretRefData(ctx, client, namespace, selector)
 	if err != nil {
@@ -105,7 +105,7 @@ func GetSecretRefValue(ctx context.Context, client ctrl.Reader, namespace string
 	return string(data), nil
 }
 
-// GetSecretRefData returns the value of a secret in the supplied namespace
+// GetSecretRefData returns the value of a secret in the supplied namespace.
 func GetSecretRefData(ctx context.Context, client ctrl.Reader, namespace string, selector *corev1.SecretKeySelector) ([]byte, error) {
 	secret, err := GetSecret(ctx, client, selector.Name, namespace)
 	if err != nil {
@@ -119,7 +119,7 @@ func GetSecretRefData(ctx context.Context, client ctrl.Reader, namespace string,
 	return nil, fmt.Errorf("key %s not found in secret %s", selector.Key, selector.Name)
 }
 
-// GetConfigMapRefValue returns the value of a configmap in the supplied namespace
+// GetConfigMapRefValue returns the value of a configmap in the supplied namespace.
 func GetConfigMapRefValue(ctx context.Context, client ctrl.Reader, namespace string, selector *corev1.ConfigMapKeySelector) (string, error) {
 	cm, err := GetConfigMap(ctx, client, selector.Name, namespace)
 	if err != nil {
diff --git a/pkg/util/kubernetes/collection.go b/pkg/util/kubernetes/collection.go
index c3fd2de..54e3449 100644
--- a/pkg/util/kubernetes/collection.go
+++ b/pkg/util/kubernetes/collection.go
@@ -36,12 +36,12 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// A Collection is a container of Kubernetes resources
+// A Collection is a container of Kubernetes resources.
 type Collection struct {
 	items []ctrl.Object
 }
 
-// NewCollection creates a new empty collection
+// NewCollection creates a new empty collection.
 func NewCollection(objects ...ctrl.Object) *Collection {
 	collection := Collection{
 		items: make([]ctrl.Object, 0, len(objects)),
@@ -52,17 +52,17 @@ func NewCollection(objects ...ctrl.Object) *Collection {
 	return &collection
 }
 
-// Size returns the number of resources belonging to the collection
+// Size returns the number of resources belonging to the collection.
 func (c *Collection) Size() int {
 	return len(c.items)
 }
 
-// Items returns all resources belonging to the collection
+// Items returns all resources belonging to the collection.
 func (c *Collection) Items() []ctrl.Object {
 	return c.items
 }
 
-// AsKubernetesList returns all resources wrapped in a Kubernetes list
+// AsKubernetesList returns all resources wrapped in a Kubernetes list.
 func (c *Collection) AsKubernetesList() *corev1.List {
 	lst := corev1.List{
 		TypeMeta: metav1.TypeMeta{
@@ -80,26 +80,26 @@ func (c *Collection) AsKubernetesList() *corev1.List {
 	return &lst
 }
 
-// Add adds a resource to the collection
+// Add adds a resource to the collection.
 func (c *Collection) Add(resource ctrl.Object) {
 	if resource != nil {
 		c.items = append(c.items, resource)
 	}
 }
 
-// AddFirst adds a resource to the head of the collection
+// AddFirst adds a resource to the head of the collection.
 func (c *Collection) AddFirst(resource ctrl.Object) {
 	if resource != nil {
 		c.items = append([]ctrl.Object{resource}, c.items...)
 	}
 }
 
-// AddAll adds all resources to the collection
+// AddAll adds all resources to the collection.
 func (c *Collection) AddAll(resource []ctrl.Object) {
 	c.items = append(c.items, resource...)
 }
 
-// VisitDeployment executes the visitor function on all Deployment resources
+// VisitDeployment executes the visitor function on all Deployment resources.
 func (c *Collection) VisitDeployment(visitor func(*appsv1.Deployment)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*appsv1.Deployment); ok {
@@ -108,7 +108,7 @@ func (c *Collection) VisitDeployment(visitor func(*appsv1.Deployment)) {
 	})
 }
 
-// VisitDeploymentE executes the visitor function on all Deployment resources
+// VisitDeploymentE executes the visitor function on all Deployment resources.
 func (c *Collection) VisitDeploymentE(visitor func(*appsv1.Deployment) error) error {
 	return c.VisitE(func(res runtime.Object) error {
 		if conv, ok := res.(*appsv1.Deployment); ok {
@@ -119,7 +119,7 @@ func (c *Collection) VisitDeploymentE(visitor func(*appsv1.Deployment) error) er
 	})
 }
 
-// GetDeployment returns a Deployment that matches the given function
+// GetDeployment returns a Deployment that matches the given function.
 func (c *Collection) GetDeployment(filter func(*appsv1.Deployment) bool) *appsv1.Deployment {
 	var retValue *appsv1.Deployment
 	c.VisitDeployment(func(re *appsv1.Deployment) {
@@ -130,7 +130,7 @@ func (c *Collection) GetDeployment(filter func(*appsv1.Deployment) bool) *appsv1
 	return retValue
 }
 
-// GetDeploymentForIntegration returns a Deployment for the given integration
+// GetDeploymentForIntegration returns a Deployment for the given integration.
 func (c *Collection) GetDeploymentForIntegration(integration *v1.Integration) *appsv1.Deployment {
 	if integration == nil {
 		return nil
@@ -141,12 +141,12 @@ func (c *Collection) GetDeploymentForIntegration(integration *v1.Integration) *a
 	})
 }
 
-// HasDeployment returns true if a deployment matching the given condition is present
+// HasDeployment returns true if a deployment matching the given condition is present.
 func (c *Collection) HasDeployment(filter func(*appsv1.Deployment) bool) bool {
 	return c.GetDeployment(filter) != nil
 }
 
-// RemoveDeployment removes and returns a Deployment that matches the given function
+// RemoveDeployment removes and returns a Deployment that matches the given function.
 func (c *Collection) RemoveDeployment(filter func(*appsv1.Deployment) bool) *appsv1.Deployment {
 	res := c.Remove(func(res runtime.Object) bool {
 		if conv, ok := res.(*appsv1.Deployment); ok {
@@ -160,7 +160,7 @@ func (c *Collection) RemoveDeployment(filter func(*appsv1.Deployment) bool) *app
 	return res.(*appsv1.Deployment)
 }
 
-// VisitConfigMap executes the visitor function on all ConfigMap resources
+// VisitConfigMap executes the visitor function on all ConfigMap resources.
 func (c *Collection) VisitConfigMap(visitor func(*corev1.ConfigMap)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*corev1.ConfigMap); ok {
@@ -169,7 +169,7 @@ func (c *Collection) VisitConfigMap(visitor func(*corev1.ConfigMap)) {
 	})
 }
 
-// GetConfigMap returns a ConfigMap that matches the given function
+// GetConfigMap returns a ConfigMap that matches the given function.
 func (c *Collection) GetConfigMap(filter func(*corev1.ConfigMap) bool) *corev1.ConfigMap {
 	var retValue *corev1.ConfigMap
 	c.VisitConfigMap(func(re *corev1.ConfigMap) {
@@ -180,7 +180,7 @@ func (c *Collection) GetConfigMap(filter func(*corev1.ConfigMap) bool) *corev1.C
 	return retValue
 }
 
-// RemoveConfigMap removes and returns a ConfigMap that matches the given function
+// RemoveConfigMap removes and returns a ConfigMap that matches the given function.
 func (c *Collection) RemoveConfigMap(filter func(*corev1.ConfigMap) bool) *corev1.ConfigMap {
 	res := c.Remove(func(res runtime.Object) bool {
 		if conv, ok := res.(*corev1.ConfigMap); ok {
@@ -194,7 +194,7 @@ func (c *Collection) RemoveConfigMap(filter func(*corev1.ConfigMap) bool) *corev
 	return res.(*corev1.ConfigMap)
 }
 
-// VisitService executes the visitor function on all Service resources
+// VisitService executes the visitor function on all Service resources.
 func (c *Collection) VisitService(visitor func(*corev1.Service)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*corev1.Service); ok {
@@ -203,7 +203,7 @@ func (c *Collection) VisitService(visitor func(*corev1.Service)) {
 	})
 }
 
-// GetService returns a Service that matches the given function
+// GetService returns a Service that matches the given function.
 func (c *Collection) GetService(filter func(*corev1.Service) bool) *corev1.Service {
 	var retValue *corev1.Service
 	c.VisitService(func(re *corev1.Service) {
@@ -214,7 +214,7 @@ func (c *Collection) GetService(filter func(*corev1.Service) bool) *corev1.Servi
 	return retValue
 }
 
-// GetUserServiceForIntegration returns a user Service for the given integration
+// GetUserServiceForIntegration returns a user Service for the given integration.
 func (c *Collection) GetUserServiceForIntegration(integration *v1.Integration) *corev1.Service {
 	if integration == nil {
 		return nil
@@ -226,7 +226,7 @@ func (c *Collection) GetUserServiceForIntegration(integration *v1.Integration) *
 	})
 }
 
-// GetServiceForIntegration returns a user Service for the given integration
+// GetServiceForIntegration returns a user Service for the given integration.
 func (c *Collection) GetServiceForIntegration(integration *v1.Integration) *corev1.Service {
 	if integration == nil {
 		return nil
@@ -236,7 +236,7 @@ func (c *Collection) GetServiceForIntegration(integration *v1.Integration) *core
 	})
 }
 
-// GetKnativeService returns a knative Service that matches the given function
+// GetKnativeService returns a knative Service that matches the given function.
 func (c *Collection) GetKnativeService(filter func(*serving.Service) bool) *serving.Service {
 	var retValue *serving.Service
 	c.VisitKnativeService(func(re *serving.Service) {
@@ -247,7 +247,7 @@ func (c *Collection) GetKnativeService(filter func(*serving.Service) bool) *serv
 	return retValue
 }
 
-// VisitRoute executes the visitor function on all Route resources
+// VisitRoute executes the visitor function on all Route resources.
 func (c *Collection) VisitRoute(visitor func(*routev1.Route)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*routev1.Route); ok {
@@ -256,7 +256,7 @@ func (c *Collection) VisitRoute(visitor func(*routev1.Route)) {
 	})
 }
 
-// GetRoute returns a Route that matches the given function
+// GetRoute returns a Route that matches the given function.
 func (c *Collection) GetRoute(filter func(*routev1.Route) bool) *routev1.Route {
 	var retValue *routev1.Route
 	c.VisitRoute(func(re *routev1.Route) {
@@ -267,7 +267,7 @@ func (c *Collection) GetRoute(filter func(*routev1.Route) bool) *routev1.Route {
 	return retValue
 }
 
-// GetCronJob returns a CronJob that matches the given function
+// GetCronJob returns a CronJob that matches the given function.
 func (c *Collection) GetCronJob(filter func(job *v1beta1.CronJob) bool) *v1beta1.CronJob {
 	var retValue *v1beta1.CronJob
 	c.VisitCronJob(func(re *v1beta1.CronJob) {
@@ -278,7 +278,7 @@ func (c *Collection) GetCronJob(filter func(job *v1beta1.CronJob) bool) *v1beta1
 	return retValue
 }
 
-// VisitCronJob executes the visitor function on all CronJob resources
+// VisitCronJob executes the visitor function on all CronJob resources.
 func (c *Collection) VisitCronJob(visitor func(*v1beta1.CronJob)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*v1beta1.CronJob); ok {
@@ -287,7 +287,7 @@ func (c *Collection) VisitCronJob(visitor func(*v1beta1.CronJob)) {
 	})
 }
 
-// VisitCronJobE executes the visitor function on all CronJob resources
+// VisitCronJobE executes the visitor function on all CronJob resources.
 func (c *Collection) VisitCronJobE(visitor func(*v1beta1.CronJob) error) error {
 	return c.VisitE(func(res runtime.Object) error {
 		if conv, ok := res.(*v1beta1.CronJob); ok {
@@ -298,7 +298,7 @@ func (c *Collection) VisitCronJobE(visitor func(*v1beta1.CronJob) error) error {
 	})
 }
 
-// VisitKnativeService executes the visitor function on all Knative serving Service resources
+// VisitKnativeService executes the visitor function on all Knative serving Service resources.
 func (c *Collection) VisitKnativeService(visitor func(*serving.Service)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*serving.Service); ok {
@@ -307,7 +307,7 @@ func (c *Collection) VisitKnativeService(visitor func(*serving.Service)) {
 	})
 }
 
-// VisitKnativeServiceE executes the visitor function on all Knative serving Service resources
+// VisitKnativeServiceE executes the visitor function on all Knative serving Service resources.
 func (c *Collection) VisitKnativeServiceE(visitor func(*serving.Service) error) error {
 	return c.VisitE(func(res runtime.Object) error {
 		if conv, ok := res.(*serving.Service); ok {
@@ -318,7 +318,7 @@ func (c *Collection) VisitKnativeServiceE(visitor func(*serving.Service) error)
 	})
 }
 
-// VisitKnativeTrigger executes the visitor function on all Knative eventing Trigger resources
+// VisitKnativeTrigger executes the visitor function on all Knative eventing Trigger resources.
 func (c *Collection) VisitKnativeTrigger(visitor func(trigger *eventing.Trigger)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(*eventing.Trigger); ok {
@@ -327,7 +327,7 @@ func (c *Collection) VisitKnativeTrigger(visitor func(trigger *eventing.Trigger)
 	})
 }
 
-// HasKnativeTrigger returns true if a Knative trigger respecting filter is found
+// HasKnativeTrigger returns true if a Knative trigger respecting filter is found.
 func (c *Collection) HasKnativeTrigger(filter func(trigger *eventing.Trigger) bool) bool {
 	var retValue *bool
 	c.VisitKnativeTrigger(func(re *eventing.Trigger) {
@@ -339,7 +339,7 @@ func (c *Collection) HasKnativeTrigger(filter func(trigger *eventing.Trigger) bo
 	return retValue != nil && *retValue
 }
 
-// GetContainer --
+// GetContainer --.
 func (c *Collection) GetContainer(filter func(container *corev1.Container) bool) *corev1.Container {
 	var retValue *corev1.Container
 
@@ -352,14 +352,14 @@ func (c *Collection) GetContainer(filter func(container *corev1.Container) bool)
 	return retValue
 }
 
-// GetContainerByName --
+// GetContainerByName --.
 func (c *Collection) GetContainerByName(name string) *corev1.Container {
 	return c.GetContainer(func(c *corev1.Container) bool {
 		return c.Name == name
 	})
 }
 
-// VisitContainer executes the visitor function on all Containers inside deployments or other resources
+// VisitContainer executes the visitor function on all Containers inside deployments or other resources.
 func (c *Collection) VisitContainer(visitor func(container *corev1.Container)) {
 	c.VisitDeployment(func(d *appsv1.Deployment) {
 		for idx := range d.Spec.Template.Spec.Containers {
@@ -381,7 +381,7 @@ func (c *Collection) VisitContainer(visitor func(container *corev1.Container)) {
 	})
 }
 
-// GetController returns the controller associated with the integration (e.g. Deployment, Knative Service or CronJob)
+// GetController returns the controller associated with the integration (e.g. Deployment, Knative Service or CronJob).
 func (c *Collection) GetController(filter func(object ctrl.Object) bool) ctrl.Object {
 	d := c.GetDeployment(func(deployment *appsv1.Deployment) bool {
 		return filter(deployment)
@@ -404,7 +404,7 @@ func (c *Collection) GetController(filter func(object ctrl.Object) bool) ctrl.Ob
 	return nil
 }
 
-// VisitPodSpec executes the visitor function on all PodSpec inside deployments or other resources
+// VisitPodSpec executes the visitor function on all PodSpec inside deployments or other resources.
 func (c *Collection) VisitPodSpec(visitor func(container *corev1.PodSpec)) {
 	c.VisitDeployment(func(d *appsv1.Deployment) {
 		visitor(&d.Spec.Template.Spec)
@@ -417,7 +417,7 @@ func (c *Collection) VisitPodSpec(visitor func(container *corev1.PodSpec)) {
 	})
 }
 
-// VisitPodTemplateMeta executes the visitor function on all PodTemplate metadata inside deployments or other resources
+// VisitPodTemplateMeta executes the visitor function on all PodTemplate metadata inside deployments or other resources.
 func (c *Collection) VisitPodTemplateMeta(visitor func(meta *metav1.ObjectMeta)) {
 	c.VisitDeployment(func(d *appsv1.Deployment) {
 		visitor(&d.Spec.Template.ObjectMeta)
@@ -430,14 +430,14 @@ func (c *Collection) VisitPodTemplateMeta(visitor func(meta *metav1.ObjectMeta))
 	})
 }
 
-// VisitKnativeConfigurationSpec executes the visitor function on all knative ConfigurationSpec inside serving Services
+// VisitKnativeConfigurationSpec executes the visitor function on all knative ConfigurationSpec inside serving Services.
 func (c *Collection) VisitKnativeConfigurationSpec(visitor func(container *serving.ConfigurationSpec)) {
 	c.VisitKnativeService(func(s *serving.Service) {
 		visitor(&s.Spec.ConfigurationSpec)
 	})
 }
 
-// VisitMetaObject executes the visitor function on all meta.Object resources
+// VisitMetaObject executes the visitor function on all meta.Object resources.
 func (c *Collection) VisitMetaObject(visitor func(metav1.Object)) {
 	c.Visit(func(res runtime.Object) {
 		if conv, ok := res.(metav1.Object); ok {
@@ -446,7 +446,7 @@ func (c *Collection) VisitMetaObject(visitor func(metav1.Object)) {
 	})
 }
 
-// Visit executes the visitor function on all resources
+// Visit executes the visitor function on all resources.
 func (c *Collection) Visit(visitor func(runtime.Object)) {
 	for _, res := range c.items {
 		visitor(res)
@@ -454,7 +454,7 @@ func (c *Collection) Visit(visitor func(runtime.Object)) {
 }
 
 // VisitE executes the visitor function on all resources breaking if the visitor function
-// returns an error
+// returns an error.
 func (c *Collection) VisitE(visitor func(runtime.Object) error) error {
 	for _, res := range c.items {
 		if err := visitor(res); err != nil {
@@ -465,7 +465,7 @@ func (c *Collection) VisitE(visitor func(runtime.Object) error) error {
 	return nil
 }
 
-// Remove removes the given element from the collection and returns it
+// Remove removes the given element from the collection and returns it.
 func (c *Collection) Remove(selector func(runtime.Object) bool) runtime.Object {
 	for idx, res := range c.items {
 		if selector(res) {
diff --git a/pkg/util/kubernetes/customclient.go b/pkg/util/kubernetes/customclient.go
index 3e38438..a4604a6 100644
--- a/pkg/util/kubernetes/customclient.go
+++ b/pkg/util/kubernetes/customclient.go
@@ -25,7 +25,7 @@ import (
 	"github.com/apache/camel-k/pkg/client"
 )
 
-// GetClientFor returns a RESTClient for the given group and version
+// GetClientFor returns a RESTClient for the given group and version.
 func GetClientFor(c client.Client, group string, version string) (*rest.RESTClient, error) {
 	conf := rest.CopyConfig(c.GetConfig())
 	conf.NegotiatedSerializer = serializer.NewCodecFactory(c.GetScheme())
diff --git a/pkg/util/kubernetes/factory.go b/pkg/util/kubernetes/factory.go
index 00f7fbf..c1e7aa5 100644
--- a/pkg/util/kubernetes/factory.go
+++ b/pkg/util/kubernetes/factory.go
@@ -32,7 +32,7 @@ var (
 	validResourceRequirementsRegexp = regexp.MustCompile(`^(requests|limits)\.(memory|cpu)=([\w\.]+)$`)
 )
 
-// NewTolerations build an array of Tolerations from an array of string
+// NewTolerations build an array of Tolerations from an array of string.
 func NewTolerations(taints []string) ([]corev1.Toleration, error) {
 	tolerations := make([]corev1.Toleration, 0)
 	for _, t := range taints {
@@ -66,7 +66,7 @@ func NewTolerations(taints []string) ([]corev1.Toleration, error) {
 	return tolerations, nil
 }
 
-// NewNodeSelectors build a map of NodeSelectors from an array of string
+// NewNodeSelectors build a map of NodeSelectors from an array of string.
 func NewNodeSelectors(nsArray []string) (map[string]string, error) {
 	nodeSelectors := make(map[string]string)
 	for _, ns := range nsArray {
@@ -81,7 +81,7 @@ func NewNodeSelectors(nsArray []string) (map[string]string, error) {
 }
 
 // NewResourceRequirements will build a CPU and memory requirements from an array of requests
-// matching <requestType.requestResource=value> (ie, limits.memory=256Mi)
+// matching <requestType.requestResource=value> (ie, limits.memory=256Mi).
 func NewResourceRequirements(reqs []string) (corev1.ResourceRequirements, error) {
 	resReq := corev1.ResourceRequirements{
 		Requests: corev1.ResourceList{},
diff --git a/pkg/util/kubernetes/loader.go b/pkg/util/kubernetes/loader.go
index eb8a798..ad4217b 100644
--- a/pkg/util/kubernetes/loader.go
+++ b/pkg/util/kubernetes/loader.go
@@ -29,7 +29,7 @@ import (
 	ctrl "sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// LoadResourceFromYaml loads a k8s resource from a yaml definition
+// LoadResourceFromYaml loads a k8s resource from a yaml definition.
 func LoadResourceFromYaml(scheme *runtime.Scheme, data string) (ctrl.Object, error) {
 	source := []byte(data)
 	jsonSource, err := yaml.ToJSON(source)
@@ -53,7 +53,7 @@ func LoadResourceFromYaml(scheme *runtime.Scheme, data string) (ctrl.Object, err
 	return o, nil
 }
 
-// LoadRawResourceFromYaml loads a k8s resource from a yaml definition without making assumptions on the underlying type
+// LoadRawResourceFromYaml loads a k8s resource from a yaml definition without making assumptions on the underlying type.
 func LoadRawResourceFromYaml(data string) (runtime.Object, error) {
 	source := []byte(data)
 	jsonSource, err := yaml.ToJSON(source)
diff --git a/pkg/util/kubernetes/log/annotation_scraper.go b/pkg/util/kubernetes/log/annotation_scraper.go
index ff5924a..c3cde92 100644
--- a/pkg/util/kubernetes/log/annotation_scraper.go
+++ b/pkg/util/kubernetes/log/annotation_scraper.go
@@ -35,7 +35,7 @@ import (
 	"k8s.io/client-go/kubernetes"
 )
 
-// SelectorScraper scrapes all pods with a given selector
+// SelectorScraper scrapes all pods with a given selector.
 type SelectorScraper struct {
 	client               kubernetes.Interface
 	namespace            string
@@ -46,7 +46,7 @@ type SelectorScraper struct {
 	L                    klog.Logger
 }
 
-// NewSelectorScraper creates a new SelectorScraper
+// NewSelectorScraper creates a new SelectorScraper.
 func NewSelectorScraper(client kubernetes.Interface, namespace string, defaultContainerName string, labelSelector string) *SelectorScraper {
 	return &SelectorScraper{
 		client:               client,
@@ -57,7 +57,7 @@ func NewSelectorScraper(client kubernetes.Interface, namespace string, defaultCo
 	}
 }
 
-// Start returns a reader that streams the log of all selected pods
+// Start returns a reader that streams the log of all selected pods.
 func (s *SelectorScraper) Start(ctx context.Context) *bufio.Reader {
 	pipeIn, pipeOut := io.Pipe()
 	bufPipeIn := bufio.NewReader(pipeIn)
diff --git a/pkg/util/kubernetes/log/pod_scraper.go b/pkg/util/kubernetes/log/pod_scraper.go
index 202c812..b54d8ed 100644
--- a/pkg/util/kubernetes/log/pod_scraper.go
+++ b/pkg/util/kubernetes/log/pod_scraper.go
@@ -41,7 +41,7 @@ var commonUserContainerNames = map[string]bool{
 	"user-container": true,
 }
 
-// PodScraper scrapes logs of a specific pod
+// PodScraper scrapes logs of a specific pod.
 type PodScraper struct {
 	namespace            string
 	podName              string
@@ -50,7 +50,7 @@ type PodScraper struct {
 	L                    klog.Logger
 }
 
-// NewPodScraper creates a new pod scraper
+// NewPodScraper creates a new pod scraper.
 func NewPodScraper(c kubernetes.Interface, namespace string, podName string, defaultContainerName string) *PodScraper {
 	return &PodScraper{
 		namespace:            namespace,
@@ -61,7 +61,7 @@ func NewPodScraper(c kubernetes.Interface, namespace string, podName string, def
 	}
 }
 
-// Start returns a reader that streams the pod logs
+// Start returns a reader that streams the pod logs.
 func (s *PodScraper) Start(ctx context.Context) *bufio.Reader {
 	pipeIn, pipeOut := io.Pipe()
 	bufPipeIn := bufio.NewReader(pipeIn)
@@ -142,7 +142,7 @@ func (s *PodScraper) handleAndRestart(ctx context.Context, err error, wait time.
 }
 
 // waitForPodRunning waits for a given pod to reach the running state.
-// It may return the internal container to watch if present
+// It may return the internal container to watch if present.
 func (s *PodScraper) waitForPodRunning(ctx context.Context, namespace string, podName string, defaultContainerName string) (string, error) {
 	pod := corev1.Pod{
 		TypeMeta: metav1.TypeMeta{
diff --git a/pkg/util/kubernetes/log/util.go b/pkg/util/kubernetes/log/util.go
index 7d67246..407ea2a 100644
--- a/pkg/util/kubernetes/log/util.go
+++ b/pkg/util/kubernetes/log/util.go
@@ -28,12 +28,12 @@ import (
 	"k8s.io/client-go/kubernetes"
 )
 
-// Print prints integrations logs to the stdout
+// Print prints integrations logs to the stdout.
 func Print(ctx context.Context, client kubernetes.Interface, integration *v1.Integration, out io.Writer) error {
 	return PrintUsingSelector(ctx, client, integration.Namespace, integration.Name, v1.IntegrationLabel+"="+integration.Name, out)
 }
 
-// PrintUsingSelector prints pod logs using a selector
+// PrintUsingSelector prints pod logs using a selector.
 func PrintUsingSelector(ctx context.Context, client kubernetes.Interface, namespace, defaultContainerName, selector string, out io.Writer) error {
 	scraper := NewSelectorScraper(client, namespace, defaultContainerName, selector)
 	reader := scraper.Start(ctx)
diff --git a/pkg/util/kubernetes/lookup.go b/pkg/util/kubernetes/lookup.go
index 92b63de..99dd8ce 100644
--- a/pkg/util/kubernetes/lookup.go
+++ b/pkg/util/kubernetes/lookup.go
@@ -27,7 +27,7 @@ import (
 	ctrl "sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// LookupConfigmap will look for any k8s Configmap with a given name in a given namespace
+// LookupConfigmap will look for any k8s Configmap with a given name in a given namespace.
 func LookupConfigmap(ctx context.Context, c client.Client, ns string, name string) *corev1.ConfigMap {
 	cm := corev1.ConfigMap{
 		TypeMeta: metav1.TypeMeta{
@@ -51,7 +51,7 @@ func LookupConfigmap(ctx context.Context, c client.Client, ns string, name strin
 	return &cm
 }
 
-// LookupSecret will look for any k8s Secret with a given name in a given namespace
+// LookupSecret will look for any k8s Secret with a given name in a given namespace.
 func LookupSecret(ctx context.Context, c client.Client, ns string, name string) *corev1.Secret {
 	secret := corev1.Secret{
 		TypeMeta: metav1.TypeMeta{
diff --git a/pkg/util/kubernetes/printer.go b/pkg/util/kubernetes/printer.go
index 7f50a38..a41aafa 100644
--- a/pkg/util/kubernetes/printer.go
+++ b/pkg/util/kubernetes/printer.go
@@ -24,7 +24,7 @@ import (
 	"k8s.io/apimachinery/pkg/runtime"
 )
 
-// CLIPrinter is delegated to print the runtime object
+// CLIPrinter is delegated to print the runtime object.
 type CLIPrinter struct {
 	// It accepts either yaml or json format
 	Format string
diff --git a/pkg/util/kubernetes/replace.go b/pkg/util/kubernetes/replace.go
index 81345e3..58533b9 100644
--- a/pkg/util/kubernetes/replace.go
+++ b/pkg/util/kubernetes/replace.go
@@ -36,7 +36,7 @@ import (
 	"github.com/apache/camel-k/pkg/client"
 )
 
-// ReplaceResource allows to completely replace a resource on Kubernetes, taking care of immutable fields and resource versions
+// ReplaceResource allows to completely replace a resource on Kubernetes, taking care of immutable fields and resource versions.
 func ReplaceResource(ctx context.Context, c client.Client, res ctrl.Object) error {
 	err := c.Create(ctx, res)
 	if err != nil && k8serrors.IsAlreadyExists(err) {
diff --git a/pkg/util/kubernetes/resolver.go b/pkg/util/kubernetes/resolver.go
index 53cbc3e..c70f564 100644
--- a/pkg/util/kubernetes/resolver.go
+++ b/pkg/util/kubernetes/resolver.go
@@ -28,7 +28,7 @@ import (
 	controller "sigs.k8s.io/controller-runtime/pkg/client"
 )
 
-// ResolveSources --
+// ResolveSources --.
 func ResolveSources(elements []v1.SourceSpec, mapLookup func(string) (*corev1.ConfigMap, error)) ([]v1.SourceSpec, error) {
 	for i := 0; i < len(elements); i++ {
 		r := &elements[i]
@@ -41,7 +41,7 @@ func ResolveSources(elements []v1.SourceSpec, mapLookup func(string) (*corev1.Co
 	return elements, nil
 }
 
-// ResolveResource --
+// ResolveResource --.
 func ResolveResource(elements []v1.ResourceSpec, mapLookup func(string) (*corev1.ConfigMap, error)) ([]v1.ResourceSpec, error) {
 	for i := 0; i < len(elements); i++ {
 		r := &elements[i]
@@ -54,7 +54,7 @@ func ResolveResource(elements []v1.ResourceSpec, mapLookup func(string) (*corev1
 	return elements, nil
 }
 
-// Resolve --
+// Resolve --.
 func Resolve(data *v1.DataSpec, mapLookup func(string) (*corev1.ConfigMap, error)) error {
 	// if it is a reference, get the content from the
 	// referenced ConfigMap
@@ -94,7 +94,7 @@ func Resolve(data *v1.DataSpec, mapLookup func(string) (*corev1.ConfigMap, error
 	return nil
 }
 
-// ResolveIntegrationSources --
+// ResolveIntegrationSources --.
 func ResolveIntegrationSources(
 	context context.Context,
 	client controller.Reader,
@@ -120,7 +120,7 @@ func ResolveIntegrationSources(
 	})
 }
 
-// ResolveIntegrationResources --
+// ResolveIntegrationResources --.
 func ResolveIntegrationResources(
 	context context.Context,
 	client controller.Reader,
diff --git a/pkg/util/kubernetes/sanitize.go b/pkg/util/kubernetes/sanitize.go
index 7e35f57..e9701a9 100644
--- a/pkg/util/kubernetes/sanitize.go
+++ b/pkg/util/kubernetes/sanitize.go
@@ -28,7 +28,7 @@ import (
 
 var disallowedChars = regexp.MustCompile(`[^a-z0-9-]`)
 
-// SanitizeName sanitizes the given name to be compatible with k8s
+// SanitizeName sanitizes the given name to be compatible with k8s.
 func SanitizeName(name string) string {
 	name = filepath.Base(name)
 	name = strings.Split(name, ".")[0]
@@ -39,7 +39,7 @@ func SanitizeName(name string) string {
 	return name
 }
 
-// SanitizeLabel sanitizes the given name to be compatible with k8s
+// SanitizeLabel sanitizes the given name to be compatible with k8s.
 func SanitizeLabel(name string) string {
 	name = strings.ToLower(name)
 	name = disallowedChars.ReplaceAllString(name, "")
diff --git a/pkg/util/kubernetes/util.go b/pkg/util/kubernetes/util.go
index bd1deb3..f9fe01a 100644
--- a/pkg/util/kubernetes/util.go
+++ b/pkg/util/kubernetes/util.go
@@ -24,12 +24,12 @@ import (
 	"github.com/apache/camel-k/pkg/util"
 )
 
-// ToJSON marshal to json format
+// ToJSON marshal to json format.
 func ToJSON(value runtime.Object) ([]byte, error) {
 	return json.Marshal(value)
 }
 
-// ToYAML marshal to yaml format
+// ToYAML marshal to yaml format.
 func ToYAML(value runtime.Object) ([]byte, error) {
 	data, err := ToJSON(value)
 	if err != nil {
@@ -39,7 +39,7 @@ func ToYAML(value runtime.Object) ([]byte, error) {
 	return util.JSONToYAML(data)
 }
 
-// ToYAMLNoManagedFields marshal to yaml format but without metadata.managedFields
+// ToYAMLNoManagedFields marshal to yaml format but without metadata.managedFields.
 func ToYAMLNoManagedFields(value runtime.Object) ([]byte, error) {
 	jsondata, err := ToJSON(value)
 	if err != nil {
diff --git a/pkg/util/label/label.go b/pkg/util/label/label.go
index 671034e..c84b76b 100644
--- a/pkg/util/label/label.go
+++ b/pkg/util/label/label.go
@@ -36,7 +36,7 @@ var AdditionalLabels = ""
 
 var FixedLabels = map[string]string{}
 
-// parses the labels early on and fail fast if there are errors
+// parses the labels early on and fail fast if there are errors.
 func init() {
 	checkAdditionalLabels()
 }
@@ -52,7 +52,7 @@ func checkAdditionalLabels() {
 	}
 }
 
-// parses the AdditionalLabels variable and returns as map[string]string
+// parses the AdditionalLabels variable and returns as map[string]string.
 func AddLabels(integration string) map[string]string {
 	definitiveLabels := labels.Set{
 		v1.IntegrationLabel: integration,
diff --git a/pkg/util/log/log.go b/pkg/util/log/log.go
index f3ca598..2286047 100644
--- a/pkg/util/log/log.go
+++ b/pkg/util/log/log.go
@@ -26,7 +26,7 @@ import (
 	logf "sigs.k8s.io/controller-runtime/pkg/log"
 )
 
-// Log --
+// Log --.
 var Log Logger
 
 func init() {
@@ -35,61 +35,61 @@ func init() {
 	}
 }
 
-// Injectable identifies objects that can receive a Logger
+// Injectable identifies objects that can receive a Logger.
 type Injectable interface {
 	InjectLogger(Logger)
 }
 
-// Logger --
+// Logger --.
 type Logger struct {
 	delegate logr.Logger
 }
 
-// Debugf --
+// Debugf --.
 func (l Logger) Debugf(format string, args ...interface{}) {
 	l.delegate.V(1).Info(fmt.Sprintf(format, args...))
 }
 
-// Infof --
+// Infof --.
 func (l Logger) Infof(format string, args ...interface{}) {
 	l.delegate.Info(fmt.Sprintf(format, args...))
 }
 
-// Errorf --
+// Errorf --.
 func (l Logger) Errorf(err error, format string, args ...interface{}) {
 	l.delegate.Error(err, fmt.Sprintf(format, args...))
 }
 
-// Debug --
+// Debug --.
 func (l Logger) Debug(msg string, keysAndValues ...interface{}) {
 	l.delegate.V(1).Info(msg, keysAndValues...)
 }
 
-// Info --
+// Info --.
 func (l Logger) Info(msg string, keysAndValues ...interface{}) {
 	l.delegate.Info(msg, keysAndValues...)
 }
 
-// Error --
+// Error --.
 func (l Logger) Error(err error, msg string, keysAndValues ...interface{}) {
 	l.delegate.Error(err, msg, keysAndValues...)
 }
 
-// WithName --
+// WithName --.
 func (l Logger) WithName(name string) Logger {
 	return Logger{
 		delegate: l.delegate.WithName(name),
 	}
 }
 
-// WithValues --
+// WithValues --.
 func (l Logger) WithValues(keysAndValues ...interface{}) Logger {
 	return Logger{
 		delegate: l.delegate.WithValues(keysAndValues...),
 	}
 }
 
-// ForBuild --
+// ForBuild --.
 func (l Logger) ForBuild(target *v1.Build) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -99,7 +99,7 @@ func (l Logger) ForBuild(target *v1.Build) Logger {
 	)
 }
 
-// ForIntegration --
+// ForIntegration --.
 func (l Logger) ForIntegration(target *v1.Integration) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -109,7 +109,7 @@ func (l Logger) ForIntegration(target *v1.Integration) Logger {
 	)
 }
 
-// ForIntegrationKit --
+// ForIntegrationKit --.
 func (l Logger) ForIntegrationKit(target *v1.IntegrationKit) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -119,7 +119,7 @@ func (l Logger) ForIntegrationKit(target *v1.IntegrationKit) Logger {
 	)
 }
 
-// ForIntegrationPlatform --
+// ForIntegrationPlatform --.
 func (l Logger) ForIntegrationPlatform(target *v1.IntegrationPlatform) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -129,7 +129,7 @@ func (l Logger) ForIntegrationPlatform(target *v1.IntegrationPlatform) Logger {
 	)
 }
 
-// ForKamelet --
+// ForKamelet --.
 func (l Logger) ForKamelet(target *v1alpha1.Kamelet) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -139,7 +139,7 @@ func (l Logger) ForKamelet(target *v1alpha1.Kamelet) Logger {
 	)
 }
 
-// ForKameletBinding --
+// ForKameletBinding --.
 func (l Logger) ForKameletBinding(target *v1alpha1.KameletBinding) Logger {
 	return l.WithValues(
 		"api-version", target.APIVersion,
@@ -155,27 +155,27 @@ func (l Logger) ForKameletBinding(target *v1alpha1.KameletBinding) Logger {
 //
 // ***********************************
 
-// WithName --
+// WithName --.
 func WithName(name string) Logger {
 	return Log.WithName(name)
 }
 
-// WithValues --
+// WithValues --.
 func WithValues(keysAndValues ...interface{}) Logger {
 	return Log.WithValues(keysAndValues...)
 }
 
-// ForIntegration --
+// ForIntegration --.
 func ForIntegration(target *v1.Integration) Logger {
 	return Log.ForIntegration(target)
 }
 
-// ForIntegrationKit --
+// ForIntegrationKit --.
 func ForIntegrationKit(target *v1.IntegrationKit) Logger {
 	return Log.ForIntegrationKit(target)
 }
 
-// ForIntegrationPlatform --
+// ForIntegrationPlatform --.
 func ForIntegrationPlatform(target *v1.IntegrationPlatform) Logger {
 	return Log.ForIntegrationPlatform(target)
 }
@@ -186,32 +186,32 @@ func ForIntegrationPlatform(target *v1.IntegrationPlatform) Logger {
 //
 // ***********************************
 
-// Debugf --
+// Debugf --.
 func Debugf(format string, args ...interface{}) {
 	Log.Debugf(format, args...)
 }
 
-// Infof --
+// Infof --.
 func Infof(format string, args ...interface{}) {
 	Log.Infof(format, args...)
 }
 
-// Errorf --
+// Errorf --.
 func Errorf(err error, format string, args ...interface{}) {
 	Log.Errorf(err, format, args...)
 }
 
-// Debug --
+// Debug --.
 func Debug(msg string, keysAndValues ...interface{}) {
 	Log.Debug(msg, keysAndValues...)
 }
 
-// Info --
+// Info --.
 func Info(msg string, keysAndValues ...interface{}) {
 	Log.Info(msg, keysAndValues...)
 }
 
-// Error --
+// Error --.
 func Error(err error, msg string, keysAndValues ...interface{}) {
 	Log.Error(err, msg, keysAndValues...)
 }
diff --git a/pkg/util/maven/maven_project.go b/pkg/util/maven/maven_project.go
index 5ea68e8..48ae3a8 100644
--- a/pkg/util/maven/maven_project.go
+++ b/pkg/util/maven/maven_project.go
@@ -89,7 +89,7 @@ func (p *Project) ReplaceDependency(dep Dependency) {
 	}
 }
 
-// AddDependency adds a dependency to maven's dependencies
+// AddDependency adds a dependency to maven's dependencies.
 func (p *Project) AddDependency(dep Dependency) {
 	for _, d := range p.Dependencies {
 		// Check if the given dependency is already included in the dependency list
@@ -101,19 +101,19 @@ func (p *Project) AddDependency(dep Dependency) {
 	p.Dependencies = append(p.Dependencies, dep)
 }
 
-// AddDependencies adds dependencies to maven's dependencies
+// AddDependencies adds dependencies to maven's dependencies.
 func (p *Project) AddDependencies(deps ...Dependency) {
 	for _, d := range deps {
 		p.AddDependency(d)
 	}
 }
 
-// AddDependencyGAV adds a dependency to maven's dependencies
+// AddDependencyGAV adds a dependency to maven's dependencies.
 func (p *Project) AddDependencyGAV(groupID string, artifactID string, version string) {
 	p.AddDependency(NewDependency(groupID, artifactID, version))
 }
 
-// AddEncodedDependencyGAV adds a dependency in GAV format to maven's dependencies
+// AddEncodedDependencyGAV adds a dependency in GAV format to maven's dependencies.
 func (p *Project) AddEncodedDependencyGAV(gav string) {
 	if d, err := ParseGAV(gav); err == nil {
 		// TODO: error handling
@@ -181,7 +181,7 @@ func (m Properties) MarshalXML(e *xml.Encoder, start xml.StartElement) error {
 	return e.EncodeToken(start.End())
 }
 
-// NewDependency creates an new dependency from the given GAV
+// NewDependency creates an new dependency from the given GAV.
 func NewDependency(groupID string, artifactID string, version string) Dependency {
 	return Dependency{
 		GroupID:    groupID,
@@ -199,7 +199,7 @@ func NewDependency(groupID string, artifactID string, version string) Dependency
 //
 //     http://my-nexus:8081/repository/publicc@id=my-repo@snapshots
 //
-// That enables snapshots and sets the repository id to `my-repo`
+// That enables snapshots and sets the repository id to `my-repo`.
 func NewRepository(repo string) v1.Repository {
 	r := v1.Repository{
 		URL: repo,
diff --git a/pkg/util/maven/maven_settings.go b/pkg/util/maven/maven_settings.go
index cc06088..b9da8bf 100644
--- a/pkg/util/maven/maven_settings.go
+++ b/pkg/util/maven/maven_settings.go
@@ -30,7 +30,7 @@ import (
 )
 
 // DefaultMavenRepositories is a comma separated list of default maven repositories
-// This variable can be overridden at build time
+// This variable can be overridden at build time.
 var DefaultMavenRepositories = "https://repo.maven.apache.org/maven2@id=central"
 
 func (s Settings) MarshalBytes() ([]byte, error) {
diff --git a/pkg/util/maven/maven_types.go b/pkg/util/maven/maven_types.go
index e2ea006..0874d0f 100644
--- a/pkg/util/maven/maven_types.go
+++ b/pkg/util/maven/maven_types.go
@@ -52,7 +52,7 @@ type Execution struct {
 
 type Properties map[string]string
 
-// Settings models a Maven settings
+// Settings models a Maven settings.
 type Settings struct {
 	XMLName           xml.Name
 	XMLNs             string    `xml:"xmlns,attr"`
@@ -63,7 +63,7 @@ type Settings struct {
 	Mirrors           []Mirror  `xml:"mirrors>mirror,omitempty"`
 }
 
-// Project models a Maven project
+// Project models a Maven project.
 type Project struct {
 	XMLName              xml.Name
 	XMLNs                string                `xml:"xmlns,attr"`
@@ -81,18 +81,18 @@ type Project struct {
 	Build                *Build                `xml:"build,omitempty"`
 }
 
-// Exclusion models a dependency exclusion
+// Exclusion models a dependency exclusion.
 type Exclusion struct {
 	GroupID    string `xml:"groupId" yaml:"groupId"`
 	ArtifactID string `xml:"artifactId" yaml:"artifactId"`
 }
 
-// DependencyManagement models dependency management
+// DependencyManagement models dependency management.
 type DependencyManagement struct {
 	Dependencies []Dependency `xml:"dependencies>dependency,omitempty"`
 }
 
-// Dependency models a dependency
+// Dependency models a dependency.
 type Dependency struct {
 	GroupID    string       `xml:"groupId" yaml:"groupId"`
 	ArtifactID string       `xml:"artifactId" yaml:"artifactId"`
diff --git a/pkg/util/minikube/registry.go b/pkg/util/minikube/registry.go
index bf0e92d..e327867 100644
--- a/pkg/util/minikube/registry.go
+++ b/pkg/util/minikube/registry.go
@@ -33,7 +33,7 @@ const (
 	registryNamespace = "kube-system"
 )
 
-// FindRegistry returns the Minikube addon registry location if any
+// FindRegistry returns the Minikube addon registry location if any.
 func FindRegistry(ctx context.Context, c client.Client) (*string, error) {
 	svcs := corev1.ServiceList{
 		TypeMeta: metav1.TypeMeta{
diff --git a/pkg/util/modeline/types.go b/pkg/util/modeline/types.go
index dce5e88..3677863 100644
--- a/pkg/util/modeline/types.go
+++ b/pkg/util/modeline/types.go
@@ -17,7 +17,7 @@ limitations under the License.
 
 package modeline
 
-// Option represents a key/(optional)value modeline option
+// Option represents a key/(optional)value modeline option.
 type Option struct {
 	Name  string
 	Value string
diff --git a/pkg/util/monitoring/register.go b/pkg/util/monitoring/register.go
index bce68d7..2389c39 100644
--- a/pkg/util/monitoring/register.go
+++ b/pkg/util/monitoring/register.go
@@ -27,7 +27,7 @@ import (
 
 type registerFunction func(*runtime.Scheme) error
 
-// AddToScheme adds monitoring types to the scheme
+// AddToScheme adds monitoring types to the scheme.
 func AddToScheme(scheme *runtime.Scheme) error {
 	var err error
 
diff --git a/pkg/util/olm/operator.go b/pkg/util/olm/operator.go
index 9028dc6..a54a8a7 100644
--- a/pkg/util/olm/operator.go
+++ b/pkg/util/olm/operator.go
@@ -41,29 +41,29 @@ import (
 
 // The following properties can be overridden at build time via ldflags
 
-// DefaultOperatorName is the Camel K operator name in OLM
+// DefaultOperatorName is the Camel K operator name in OLM.
 var DefaultOperatorName = "camel-k-operator"
 
-// DefaultPackage is the Camel K package in OLM
+// DefaultPackage is the Camel K package in OLM.
 var DefaultPackage = "camel-k"
 
-// DefaultChannel is the distribution channel in Operator Hub
+// DefaultChannel is the distribution channel in Operator Hub.
 var DefaultChannel = "stable"
 
-// DefaultSource is the name of the operator source where the operator is published
+// DefaultSource is the name of the operator source where the operator is published.
 var DefaultSource = "community-operators"
 
-// DefaultSourceNamespace is the namespace of the operator source
+// DefaultSourceNamespace is the namespace of the operator source.
 var DefaultSourceNamespace = "openshift-marketplace"
 
-// DefaultStartingCSV contains the specific version to install
+// DefaultStartingCSV contains the specific version to install.
 var DefaultStartingCSV = ""
 
 // DefaultGlobalNamespace indicates a namespace containing an OperatorGroup that enables the operator to watch all namespaces.
 // It will be used in global installation mode.
 var DefaultGlobalNamespace = "openshift-operators"
 
-// Options contains information about an operator in OLM
+// Options contains information about an operator in OLM.
 type Options struct {
 	OperatorName    string
 	Package         string
@@ -74,7 +74,7 @@ type Options struct {
 	GlobalNamespace string
 }
 
-// IsOperatorInstalled tells if a OLM CSV or a Subscription is already installed in the namespace
+// IsOperatorInstalled tells if a OLM CSV or a Subscription is already installed in the namespace.
 func IsOperatorInstalled(ctx context.Context, client client.Client, namespace string, global bool, options Options) (bool, error) {
 	options, err := fillDefaults(options, client)
 	if err != nil {
@@ -96,7 +96,7 @@ func IsOperatorInstalled(ctx context.Context, client client.Client, namespace st
 	return false, nil
 }
 
-// HasPermissionToInstall checks if the current user/serviceaccount has the right permissions to install camel k via OLM
+// HasPermissionToInstall checks if the current user/serviceaccount has the right permissions to install camel k via OLM.
 func HasPermissionToInstall(ctx context.Context, client client.Client, namespace string, global bool, options Options) (bool, error) {
 	if ok, err := kubernetes.CheckPermission(ctx, client, operatorsv1alpha1.GroupName, "clusterserviceversions", namespace, options.Package, "list"); err != nil {
 		return false, err
@@ -144,7 +144,7 @@ func HasPermissionToInstall(ctx context.Context, client client.Client, namespace
 	return true, nil
 }
 
-// Install creates a subscription for the OLM package
+// Install creates a subscription for the OLM package.
 func Install(ctx context.Context, client client.Client, namespace string, global bool, options Options, collection *kubernetes.Collection,
 	tolerations []string, nodeSelectors []string, resourcesRequirements []string, envVars []string) (bool, error) {
 	options, err := fillDefaults(options, client)
@@ -272,7 +272,7 @@ func maybeSetEnvVars(sub *operatorsv1alpha1.Subscription, envVars []string) erro
 	return nil
 }
 
-// Uninstall removes CSV and subscription from the namespace
+// Uninstall removes CSV and subscription from the namespace.
 func Uninstall(ctx context.Context, client client.Client, namespace string, global bool, options Options) error {
 	options, err := fillDefaults(options, client)
 	if err != nil {
diff --git a/pkg/util/openshift/openshift.go b/pkg/util/openshift/openshift.go
index 4cb247c..66da206 100644
--- a/pkg/util/openshift/openshift.go
+++ b/pkg/util/openshift/openshift.go
@@ -22,7 +22,7 @@ import (
 	"k8s.io/client-go/kubernetes"
 )
 
-// IsOpenShift returns true if we are connected to a OpenShift cluster
+// IsOpenShift returns true if we are connected to a OpenShift cluster.
 func IsOpenShift(client kubernetes.Interface) (bool, error) {
 	_, err := client.Discovery().ServerResourcesForGroupVersion("image.openshift.io/v1")
 	if err != nil && errors.IsNotFound(err) {
diff --git a/pkg/util/openshift/register.go b/pkg/util/openshift/register.go
index 4ef8c51..7d84f76 100644
--- a/pkg/util/openshift/register.go
+++ b/pkg/util/openshift/register.go
@@ -35,7 +35,7 @@ import (
 
 type registerFunction func(*runtime.Scheme) error
 
-// AddToScheme adds OpenShift types to the scheme
+// AddToScheme adds OpenShift types to the scheme.
 func AddToScheme(scheme *runtime.Scheme) error {
 	var err error
 
diff --git a/pkg/util/property/property.go b/pkg/util/property/property.go
index e321d03..7f02b7a 100644
--- a/pkg/util/property/property.go
+++ b/pkg/util/property/property.go
@@ -25,7 +25,7 @@ import (
 	"github.com/pkg/errors"
 )
 
-// EncodePropertyFileEntry converts the given key/value pair into a .properties file entry
+// EncodePropertyFileEntry converts the given key/value pair into a .properties file entry.
 func EncodePropertyFileEntry(key, value string) (string, error) {
 	p := properties.NewProperties()
 	p.DisableExpansion = true
@@ -40,7 +40,7 @@ func EncodePropertyFileEntry(key, value string) (string, error) {
 	return pair, nil
 }
 
-// EncodePropertyFile encodes a property map into a .properties file
+// EncodePropertyFile encodes a property map into a .properties file.
 func EncodePropertyFile(sourceProperties map[string]string) (string, error) {
 	props := properties.LoadMap(sourceProperties)
 	props.DisableExpansion = true
@@ -53,7 +53,7 @@ func EncodePropertyFile(sourceProperties map[string]string) (string, error) {
 	return buf.String(), nil
 }
 
-// SplitPropertyFileEntry splits an encoded property into key/value pair, without decoding the content
+// SplitPropertyFileEntry splits an encoded property into key/value pair, without decoding the content.
 func SplitPropertyFileEntry(entry string) (string, string) {
 	pair := strings.SplitN(entry, "=", 2)
 	var k, v string
diff --git a/pkg/util/registry/registry.go b/pkg/util/registry/registry.go
index 17829cd..604f51c 100644
--- a/pkg/util/registry/registry.go
+++ b/pkg/util/registry/registry.go
@@ -28,7 +28,7 @@ var knownServersByRegistry = map[string]string{
 	"docker.io": "https://index.docker.io/v1/",
 }
 
-// Auth contains basic information for authenticating against a container registry
+// Auth contains basic information for authenticating against a container registry.
 type Auth struct {
 	Server   string
 	Username string
@@ -46,14 +46,14 @@ type dockerConfig struct {
 	Auth string `json:"auth,omitempty"`
 }
 
-// IsSet returns if information has been set on the object
+// IsSet returns if information has been set on the object.
 func (a Auth) IsSet() bool {
 	return a.Server != "" ||
 		a.Username != "" ||
 		a.Password != ""
 }
 
-// validate checks if all fields are populated correctly
+// validate checks if all fields are populated correctly.
 func (a Auth) validate() error {
 	if a.getActualServer() == "" || a.Username == "" {
 		return errors.New("not enough information to generate a registry authentication file")
@@ -62,7 +62,7 @@ func (a Auth) validate() error {
 	return nil
 }
 
-// GenerateDockerConfig generates a Docker compatible config.json file
+// GenerateDockerConfig generates a Docker compatible config.json file.
 func (a Auth) GenerateDockerConfig() ([]byte, error) {
 	if err := a.validate(); err != nil {
 		return nil, err
diff --git a/pkg/util/source/inspector.go b/pkg/util/source/inspector.go
index 4f5bebb..197ac7c 100644
--- a/pkg/util/source/inspector.go
+++ b/pkg/util/source/inspector.go
@@ -159,12 +159,12 @@ var (
 	}
 )
 
-// Inspector --
+// Inspector --.
 type Inspector interface {
 	Extract(v1.SourceSpec, *Metadata) error
 }
 
-// InspectorForLanguage --
+// InspectorForLanguage --.
 func InspectorForLanguage(catalog *camel.RuntimeCatalog, language v1.Language) Inspector {
 	switch language {
 	case v1.LanguageJavaSource:
@@ -215,7 +215,7 @@ func (i baseInspector) Extract(v1.SourceSpec, *Metadata) error {
 	return nil
 }
 
-// discoverDependencies returns a list of dependencies required by the given source code
+// discoverDependencies returns a list of dependencies required by the given source code.
 func (i *baseInspector) discoverCapabilities(source v1.SourceSpec, meta *Metadata) {
 	uris := util.StringSliceJoin(meta.FromURIs, meta.ToURIs)
 
@@ -236,7 +236,7 @@ func (i *baseInspector) discoverCapabilities(source v1.SourceSpec, meta *Metadat
 	}
 }
 
-// discoverDependencies returns a list of dependencies required by the given source code
+// discoverDependencies returns a list of dependencies required by the given source code.
 func (i *baseInspector) discoverDependencies(source v1.SourceSpec, meta *Metadata) {
 	for _, uri := range meta.FromURIs {
 		candidateComp, scheme := i.catalog.DecodeComponent(uri)
@@ -304,7 +304,7 @@ func (i *baseInspector) addDependency(dependency string, meta *Metadata) {
 	meta.Dependencies.Add(dependency)
 }
 
-// hasOnlyPassiveEndpoints returns true if the source has no endpoint that needs to remain always active
+// hasOnlyPassiveEndpoints returns true if the source has no endpoint that needs to remain always active.
 func (i *baseInspector) hasOnlyPassiveEndpoints(fromURIs []string) bool {
 	passivePlusHTTP := make(map[string]bool)
 	i.catalog.VisitSchemes(func(id string, scheme v1.CamelScheme) bool {
diff --git a/pkg/util/source/inspector_xml.go b/pkg/util/source/inspector_xml.go
index 40c5489..18c4827 100644
--- a/pkg/util/source/inspector_xml.go
+++ b/pkg/util/source/inspector_xml.go
@@ -24,12 +24,12 @@ import (
 	v1 "github.com/apache/camel-k/pkg/apis/camel/v1"
 )
 
-// XMLInspector --
+// XMLInspector --.
 type XMLInspector struct {
 	baseInspector
 }
 
-// Extract --
+// Extract --.
 func (i XMLInspector) Extract(source v1.SourceSpec, meta *Metadata) error {
 	content := strings.NewReader(source.Content)
 	decoder := xml.NewDecoder(content)
diff --git a/pkg/util/source/inspector_yaml.go b/pkg/util/source/inspector_yaml.go
index 44bdb7d..23f6b4d 100644
--- a/pkg/util/source/inspector_yaml.go
+++ b/pkg/util/source/inspector_yaml.go
@@ -26,12 +26,12 @@ import (
 	yaml2 "gopkg.in/yaml.v2"
 )
 
-// YAMLInspector --
+// YAMLInspector --.
 type YAMLInspector struct {
 	baseInspector
 }
 
-// Extract --
+// Extract --.
 func (i YAMLInspector) Extract(source v1.SourceSpec, meta *Metadata) error {
 	definitions := make([]map[string]interface{}, 0)
 
@@ -167,7 +167,7 @@ func (i YAMLInspector) parseStep(key string, content interface{}, meta *Metadata
 	return nil
 }
 
-// TODO nolint: gocyclo
+// TODO nolint: gocyclo.
 func (i YAMLInspector) parseStepsParam(steps []interface{}, meta *Metadata) error {
 	for _, raw := range steps {
 		if step, stepFormatOk := raw.(map[interface{}]interface{}); stepFormatOk {
diff --git a/pkg/util/source/types.go b/pkg/util/source/types.go
index 9bbbaa5..76ff789 100644
--- a/pkg/util/source/types.go
+++ b/pkg/util/source/types.go
@@ -19,7 +19,7 @@ package source
 
 import "github.com/scylladb/go-set/strset"
 
-// Metadata --
+// Metadata --.
 type Metadata struct {
 	// All starting URIs of defined routes
 	FromURIs []string
@@ -41,7 +41,7 @@ type Metadata struct {
 	Kamelets []string
 }
 
-// NewMetadata --
+// NewMetadata --.
 func NewMetadata() Metadata {
 	return Metadata{
 		FromURIs:             make([]string, 0),
diff --git a/pkg/util/sync/file.go b/pkg/util/sync/file.go
index f362d04..eb2e4f4 100644
--- a/pkg/util/sync/file.go
+++ b/pkg/util/sync/file.go
@@ -26,7 +26,7 @@ import (
 	"github.com/radovskyb/watcher"
 )
 
-// File returns a channel that signals each time the content of the file changes
+// File returns a channel that signals each time the content of the file changes.
 func File(ctx context.Context, path string) (<-chan bool, error) {
 	w := watcher.New()
 	if err := w.Add(path); err != nil {
diff --git a/pkg/util/test/assertions.go b/pkg/util/test/assertions.go
index 5ba0d6c..9661310 100644
--- a/pkg/util/test/assertions.go
+++ b/pkg/util/test/assertions.go
@@ -26,7 +26,7 @@ import (
 	corev1 "k8s.io/api/core/v1"
 )
 
-// EnvVarExists --
+// EnvVarExists --.
 func EnvVarExists(t *testing.T, env []corev1.EnvVar, name string) {
 	t.Helper()
 
@@ -34,7 +34,7 @@ func EnvVarExists(t *testing.T, env []corev1.EnvVar, name string) {
 	assert.NotNil(t, ev)
 }
 
-// EnvVarHasValue --
+// EnvVarHasValue --.
 func EnvVarHasValue(t *testing.T, env []corev1.EnvVar, name string, val string) {
 	t.Helper()
 
@@ -43,7 +43,7 @@ func EnvVarHasValue(t *testing.T, env []corev1.EnvVar, name string, val string)
 	assert.Equal(t, val, ev.Value)
 }
 
-// HasVolume --
+// HasVolume --.
 func HasVolume(t *testing.T, volumes []corev1.Volume, name string) {
 	t.Helper()
 
diff --git a/pkg/util/test/client.go b/pkg/util/test/client.go
index d397fdc..50d32fb 100644
--- a/pkg/util/test/client.go
+++ b/pkg/util/test/client.go
@@ -40,7 +40,7 @@ import (
 	"sigs.k8s.io/controller-runtime/pkg/client/fake"
 )
 
-// NewFakeClient ---
+// NewFakeClient ---.
 func NewFakeClient(initObjs ...runtime.Object) (client.Client, error) {
 	scheme := clientscheme.Scheme
 
@@ -78,7 +78,7 @@ func filterObjects(scheme *runtime.Scheme, input []runtime.Object, filter func(g
 	return res
 }
 
-// FakeClient ---
+// FakeClient ---.
 type FakeClient struct {
 	controller.Client
 	kubernetes.Interface
@@ -93,7 +93,7 @@ func (c *FakeClient) CamelV1alpha1() camelv1alpha1.CamelV1alpha1Interface {
 	return c.camel.CamelV1alpha1()
 }
 
-// GetScheme ---
+// GetScheme ---.
 func (c *FakeClient) GetScheme() *runtime.Scheme {
 	return clientscheme.Scheme
 }
@@ -106,7 +106,7 @@ func (c *FakeClient) GetCurrentNamespace(kubeConfig string) (string, error) {
 	return "", nil
 }
 
-// Patch mimicks patch for server-side apply and simply creates the obj
+// Patch mimicks patch for server-side apply and simply creates the obj.
 func (c *FakeClient) Patch(ctx context.Context, obj controller.Object, patch controller.Patch, opts ...controller.PatchOption) error {
 	return c.Create(ctx, obj)
 }
diff --git a/pkg/util/uri/uri.go b/pkg/util/uri/uri.go
index 542eee4..4e722c6 100644
--- a/pkg/util/uri/uri.go
+++ b/pkg/util/uri/uri.go
@@ -31,12 +31,12 @@ var uriRegexp = regexp.MustCompile(`^[a-z0-9+][a-zA-Z0-9-+]*:.*$`)
 
 var queryExtractorRegexp = `^[^?]+\?(?:|.*[&])%s=([^&]+)(?:[&].*|$)`
 
-// HasCamelURIFormat tells if a given string may belong to a Camel URI, without checking any catalog
+// HasCamelURIFormat tells if a given string may belong to a Camel URI, without checking any catalog.
 func HasCamelURIFormat(uri string) bool {
 	return uriRegexp.MatchString(uri)
 }
 
-// GetComponent returns the Camel component used in the URI
+// GetComponent returns the Camel component used in the URI.
 func GetComponent(uri string) string {
 	parts := strings.Split(uri, ":")
 	if len(parts) <= 1 {
@@ -45,7 +45,7 @@ func GetComponent(uri string) string {
 	return parts[0]
 }
 
-// GetQueryParameter returns the given parameter from the uri, if present
+// GetQueryParameter returns the given parameter from the uri, if present.
 func GetQueryParameter(uri string, param string) string {
 	paramRegexp := regexp.MustCompile(fmt.Sprintf(queryExtractorRegexp, regexp.QuoteMeta(param)))
 	val := matchOrEmpty(paramRegexp, uri)
diff --git a/pkg/util/util.go b/pkg/util/util.go
index 745ac7c..1478e29 100644
--- a/pkg/util/util.go
+++ b/pkg/util/util.go
@@ -45,49 +45,49 @@ import (
 // By default, a temporary folder will be used.
 var MavenWorkingDirectory = ""
 
-// DefaultDependenciesDirectoryName --
+// DefaultDependenciesDirectoryName --.
 const DefaultDependenciesDirectoryName = "dependencies"
 
-// DefaultPropertiesDirectoryName --
+// DefaultPropertiesDirectoryName --.
 const DefaultPropertiesDirectoryName = "properties"
 
-// DefaultRoutesDirectoryName --
+// DefaultRoutesDirectoryName --.
 const DefaultRoutesDirectoryName = "routes"
 
-// DefaultWorkingDirectoryName --
+// DefaultWorkingDirectoryName --.
 const DefaultWorkingDirectoryName = "workspace"
 
-// CustomQuarkusDirectoryName --
+// CustomQuarkusDirectoryName --.
 const CustomQuarkusDirectoryName = "quarkus"
 
-// CustomAppDirectoryName --
+// CustomAppDirectoryName --.
 const CustomAppDirectoryName = "app"
 
-// CustomLibDirectoryName --
+// CustomLibDirectoryName --.
 const CustomLibDirectoryName = "lib/main"
 
-// ContainerDependenciesDirectory --
+// ContainerDependenciesDirectory --.
 var ContainerDependenciesDirectory = "/deployments/dependencies"
 
-// ContainerPropertiesDirectory --
+// ContainerPropertiesDirectory --.
 var ContainerPropertiesDirectory = "/etc/camel/conf.d"
 
-// ContainerRoutesDirectory --
+// ContainerRoutesDirectory --.
 var ContainerRoutesDirectory = "/etc/camel/sources"
 
-// ContainerResourcesDirectory --
+// ContainerResourcesDirectory --.
 var ContainerResourcesDirectory = "/etc/camel/resources"
 
-// ContainerQuarkusDirectoryName --
+// ContainerQuarkusDirectoryName --.
 const ContainerQuarkusDirectoryName = "/quarkus"
 
-// ContainerAppDirectoryName --
+// ContainerAppDirectoryName --.
 const ContainerAppDirectoryName = "/app"
 
-// ContainerLibDirectoryName --
+// ContainerLibDirectoryName --.
 const ContainerLibDirectoryName = "/lib/main"
 
-// QuarkusDependenciesBaseDirectory --
+// QuarkusDependenciesBaseDirectory --.
 var QuarkusDependenciesBaseDirectory = "/quarkus-app"
 
 // ListOfLazyEvaluatedEnvVars -- List of unevaluated environment variables.
@@ -158,7 +158,7 @@ func StringSliceContainsAnyOf(slice []string, items ...string) bool {
 	return false
 }
 
-// StringSliceUniqueAdd appends the given item if not already present in the slice
+// StringSliceUniqueAdd appends the given item if not already present in the slice.
 func StringSliceUniqueAdd(slice *[]string, item string) bool {
 	if slice == nil {
 		newSlice := make([]string, 0)
@@ -175,7 +175,7 @@ func StringSliceUniqueAdd(slice *[]string, item string) bool {
 	return true
 }
 
-// StringSliceUniqueConcat appends all the items of the "items" slice if they are not already present in the slice
+// StringSliceUniqueConcat appends all the items of the "items" slice if they are not already present in the slice.
 func StringSliceUniqueConcat(slice *[]string, items []string) bool {
 	changed := false
 	for _, item := range items {
@@ -375,7 +375,7 @@ func SortedStringMapKeys(m map[string]string) []string {
 	return res
 }
 
-// CopyMap clones a map of strings
+// CopyMap clones a map of strings.
 func CopyMap(source map[string]string) map[string]string {
 	if source == nil {
 		return nil
@@ -441,32 +441,32 @@ func WriteToFile(filePath string, fileContents string) error {
 
 // Local directories:
 
-// GetLocalPropertiesDir -- <mavenWorkingDirectory>/properties
+// GetLocalPropertiesDir -- <mavenWorkingDirectory>/properties.
 func GetLocalPropertiesDir() string {
 	return path.Join(MavenWorkingDirectory, DefaultPropertiesDirectoryName)
 }
 
-// GetLocalDependenciesDir --<mavenWorkingDirectory>/dependencies
+// GetLocalDependenciesDir --<mavenWorkingDirectory>/dependencies.
 func GetLocalDependenciesDir() string {
 	return path.Join(MavenWorkingDirectory, DefaultDependenciesDirectoryName)
 }
 
-// GetLocalRoutesDir -- <mavenWorkingDirectory>/routes
+// GetLocalRoutesDir -- <mavenWorkingDirectory>/routes.
 func GetLocalRoutesDir() string {
 	return path.Join(MavenWorkingDirectory, DefaultRoutesDirectoryName)
 }
 
-// GetLocalQuarkusDir -- <mavenWorkingDirectory>/quarkus
+// GetLocalQuarkusDir -- <mavenWorkingDirectory>/quarkus.
 func GetLocalQuarkusDir() string {
 	return path.Join(MavenWorkingDirectory, CustomQuarkusDirectoryName)
 }
 
-// GetLocalAppDir -- <mavenWorkingDirectory>/app
+// GetLocalAppDir -- <mavenWorkingDirectory>/app.
 func GetLocalAppDir() string {
 	return path.Join(MavenWorkingDirectory, CustomAppDirectoryName)
 }
 
-// GetLocalLibDir -- <mavenWorkingDirectory>/lib/main
+// GetLocalLibDir -- <mavenWorkingDirectory>/lib/main.
 func GetLocalLibDir() string {
 	return path.Join(MavenWorkingDirectory, CustomLibDirectoryName)
 }

[camel-k] 04/06: fix(lint): context should be propagated (contextcheck)

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit 194ae8a60057a625af99b077a20ac5800570bef1
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 15:30:33 2021 +0100

    fix(lint): context should be propagated (contextcheck)
---
 .golangci.yml                           |  1 -
 pkg/builder/s2i.go                      |  1 +
 pkg/cmd/run.go                          |  6 +++---
 pkg/cmd/run_help.go                     |  2 +-
 pkg/cmd/util_content.go                 | 20 ++++++++++----------
 pkg/cmd/util_content_test.go            | 15 ++++++++-------
 pkg/cmd/util_dependencies.go            |  6 +++---
 pkg/cmd/util_sources.go                 |  6 +++---
 pkg/controller/build/monitor_routine.go |  2 ++
 pkg/util/camel/catalog.go               |  2 +-
 10 files changed, 32 insertions(+), 29 deletions(-)

diff --git a/.golangci.yml b/.golangci.yml
index c9af8be..e7eb670 100644
--- a/.golangci.yml
+++ b/.golangci.yml
@@ -55,6 +55,5 @@ linters:
     - nilnil
     - exhaustive
     - nakedret
-    - contextcheck
     - maligned
 
diff --git a/pkg/builder/s2i.go b/pkg/builder/s2i.go
index 2f7f488..153d0a3 100644
--- a/pkg/builder/s2i.go
+++ b/pkg/builder/s2i.go
@@ -209,6 +209,7 @@ func (t *s2iTask) Do(ctx context.Context) v1.BuildStatus {
 	err = t.waitForS2iBuildCompletion(ctx, t.c, &s2iBuild)
 	if err != nil {
 		if errors.Is(err, context.Canceled) || errors.Is(err, context.DeadlineExceeded) {
+			// nolint: contextcheck
 			if err := t.cancelBuild(context.Background(), &s2iBuild); err != nil {
 				log.Errorf(err, "cannot cancel s2i Build: %s/%s", s2iBuild.Namespace, s2iBuild.Name)
 			}
diff --git a/pkg/cmd/run.go b/pkg/cmd/run.go
index 261c530..ba01178 100644
--- a/pkg/cmd/run.go
+++ b/pkg/cmd/run.go
@@ -579,7 +579,7 @@ func (o *runCmdOptions) createOrUpdateIntegration(cmd *cobra.Command, c client.C
 	}
 
 	for _, resource := range o.OpenAPIs {
-		if err = addResource(resource, &integration.Spec, o.Compression, v1.ResourceTypeOpenAPI); err != nil {
+		if err = addResource(o.Context, resource, &integration.Spec, o.Compression, v1.ResourceTypeOpenAPI); err != nil {
 			return nil, err
 		}
 	}
@@ -686,8 +686,8 @@ func (o *runCmdOptions) createOrUpdateIntegration(cmd *cobra.Command, c client.C
 	return integration, nil
 }
 
-func addResource(resourceLocation string, integrationSpec *v1.IntegrationSpec, enableCompression bool, resourceType v1.ResourceType) error {
-	if data, _, compressed, err := loadTextContent(resourceLocation, enableCompression); err == nil {
+func addResource(ctx context.Context, resourceLocation string, integrationSpec *v1.IntegrationSpec, enableCompression bool, resourceType v1.ResourceType) error {
+	if data, _, compressed, err := loadTextContent(ctx, resourceLocation, enableCompression); err == nil {
 		integrationSpec.AddResources(v1.ResourceSpec{
 			DataSpec: v1.DataSpec{
 				Name:        path.Base(resourceLocation),
diff --git a/pkg/cmd/run_help.go b/pkg/cmd/run_help.go
index 645efef..38422de 100644
--- a/pkg/cmd/run_help.go
+++ b/pkg/cmd/run_help.go
@@ -210,7 +210,7 @@ func applyOption(config *RunConfigOption, integrationSpec *v1.IntegrationSpec,
 			return fmt.Errorf("you cannot provide a file larger than 1 MB (it was %s MB), check configmap option or --volume instead", printSize)
 		}
 		// Don't allow a binary non compressed resource
-		rawData, contentType, err := loadRawContent(config.Name())
+		rawData, contentType, err := loadRawContent(context.Background(), config.Name())
 		if err != nil {
 			return err
 		}
diff --git a/pkg/cmd/util_content.go b/pkg/cmd/util_content.go
index 0ec57a4..8b52a34 100644
--- a/pkg/cmd/util_content.go
+++ b/pkg/cmd/util_content.go
@@ -43,7 +43,7 @@ func fileSize(source string) (int64, error) {
 	return fi.Size(), nil
 }
 
-func loadRawContent(source string) ([]byte, string, error) {
+func loadRawContent(ctx context.Context, source string) ([]byte, string, error) {
 	var content []byte
 	var err error
 
@@ -63,11 +63,11 @@ func loadRawContent(source string) ([]byte, string, error) {
 
 		switch u.Scheme {
 		case "github":
-			content, err = loadContentGitHub(u)
+			content, err = loadContentGitHub(ctx, u)
 		case "http":
-			content, err = loadContentHTTP(u)
+			content, err = loadContentHTTP(ctx, u)
 		case "https":
-			content, err = loadContentHTTP(u)
+			content, err = loadContentHTTP(ctx, u)
 		default:
 			return nil, "", fmt.Errorf("missing file or unsupported scheme %s", u.Scheme)
 		}
@@ -87,8 +87,8 @@ func isBinary(contentType string) bool {
 	return !strings.HasPrefix(contentType, "text")
 }
 
-func loadTextContent(source string, base64Compression bool) (string, string, bool, error) {
-	content, contentType, err := loadRawContent(source)
+func loadTextContent(ctx context.Context, source string, base64Compression bool) (string, string, bool, error) {
+	content, contentType, err := loadRawContent(ctx, source)
 	if err != nil {
 		return "", "", false, err
 	}
@@ -101,8 +101,8 @@ func loadTextContent(source string, base64Compression bool) (string, string, boo
 	return string(content), contentType, false, nil
 }
 
-func loadContentHTTP(u fmt.Stringer) ([]byte, error) {
-	req, err := http.NewRequestWithContext(context.Background(), http.MethodGet, u.String(), nil)
+func loadContentHTTP(ctx context.Context, u fmt.Stringer) ([]byte, error) {
+	req, err := http.NewRequestWithContext(ctx, http.MethodGet, u.String(), nil)
 	if err != nil {
 		return nil, err
 	}
@@ -124,7 +124,7 @@ func loadContentHTTP(u fmt.Stringer) ([]byte, error) {
 	return io.ReadAll(resp.Body)
 }
 
-func loadContentGitHub(u *url.URL) ([]byte, error) {
+func loadContentGitHub(ctx context.Context, u *url.URL) ([]byte, error) {
 	src := u.Scheme + ":" + u.Opaque
 	re := regexp.MustCompile(`^github:([^/]+)/([^/]+)/(.+)$`)
 
@@ -144,5 +144,5 @@ func loadContentGitHub(u *url.URL) ([]byte, error) {
 		return []byte{}, err
 	}
 
-	return loadContentHTTP(rawURL)
+	return loadContentHTTP(ctx, rawURL)
 }
diff --git a/pkg/cmd/util_content_test.go b/pkg/cmd/util_content_test.go
index 5684ac8..388c867 100644
--- a/pkg/cmd/util_content_test.go
+++ b/pkg/cmd/util_content_test.go
@@ -18,6 +18,7 @@ limitations under the License.
 package cmd
 
 import (
+	"context"
 	"fmt"
 	"io/ioutil"
 	"net/http"
@@ -30,7 +31,7 @@ import (
 )
 
 func TestRawContentFileMissing(t *testing.T) {
-	_, _, err := loadRawContent("dsadas")
+	_, _, err := loadRawContent(context.TODO(), "dsadas")
 	assert.NotNil(t, err)
 }
 
@@ -43,7 +44,7 @@ func TestRawBinaryContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte{1, 2, 3, 4, 5, 6}, 0o400))
 
-	data, contentType, err := loadRawContent(tmpFile.Name())
+	data, contentType, err := loadRawContent(context.TODO(), tmpFile.Name())
 	assert.Nil(t, err)
 	assert.Equal(t, []byte{1, 2, 3, 4, 5, 6}, data)
 	assert.True(t, isBinary(contentType))
@@ -58,7 +59,7 @@ func TestRawApplicationContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, err := loadRawContent(tmpFile.Name())
+	data, contentType, err := loadRawContent(context.TODO(), tmpFile.Name())
 	assert.Nil(t, err)
 	assert.Equal(t, `{"hello":"world"}`, string(data))
 	assert.False(t, isBinary(contentType))
@@ -73,7 +74,7 @@ func TestTextContentType(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, compressed, err := loadTextContent(tmpFile.Name(), false)
+	data, contentType, compressed, err := loadTextContent(context.TODO(), tmpFile.Name(), false)
 	assert.Nil(t, err)
 	assert.Equal(t, `{"hello":"world"}`, data)
 	assert.False(t, isBinary(contentType))
@@ -89,7 +90,7 @@ func TestTextCompressed(t *testing.T) {
 	assert.Nil(t, tmpFile.Close())
 	assert.Nil(t, ioutil.WriteFile(tmpFile.Name(), []byte(`{"hello":"world"}`), 0o400))
 
-	data, contentType, compressed, err := loadTextContent(tmpFile.Name(), true)
+	data, contentType, compressed, err := loadTextContent(context.TODO(), tmpFile.Name(), true)
 	assert.Nil(t, err)
 	assert.NotEqual(t, `{"hello":"world"}`, data)
 	assert.False(t, isBinary(contentType))
@@ -105,14 +106,14 @@ func TestIsBinary(t *testing.T) {
 func TestContentHttp(t *testing.T) {
 	expected := "the content"
 	svr := httptest.NewServer(http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
-		_, _ = fmt.Fprintf(w, expected)
+		_, _ = fmt.Fprint(w, expected)
 	}))
 	defer svr.Close()
 
 	u, err := url.Parse(svr.URL)
 	assert.Nil(t, err)
 
-	data, err := loadContentHTTP(u)
+	data, err := loadContentHTTP(context.TODO(), u)
 	assert.Nil(t, err)
 	assert.NotEmpty(t, data)
 	assert.Equal(t, expected, string(data))
diff --git a/pkg/cmd/util_dependencies.go b/pkg/cmd/util_dependencies.go
index 351091f..5f0a758 100644
--- a/pkg/cmd/util_dependencies.go
+++ b/pkg/cmd/util_dependencies.go
@@ -51,7 +51,7 @@ func getDependencies(ctx context.Context, args []string, additionalDependencies
 	}
 
 	// Get top-level dependencies
-	dependencies, err := getTopLevelDependencies(catalog, args)
+	dependencies, err := getTopLevelDependencies(ctx, catalog, args)
 	if err != nil {
 		return nil, err
 	}
@@ -75,13 +75,13 @@ func getDependencies(ctx context.Context, args []string, additionalDependencies
 	return dependencies, nil
 }
 
-func getTopLevelDependencies(catalog *camel.RuntimeCatalog, args []string) ([]string, error) {
+func getTopLevelDependencies(ctx context.Context, catalog *camel.RuntimeCatalog, args []string) ([]string, error) {
 	// List of top-level dependencies
 	dependencies := strset.New()
 
 	// Invoke the dependency inspector code for each source file
 	for _, source := range args {
-		data, _, _, err := loadTextContent(source, false)
+		data, _, _, err := loadTextContent(ctx, source, false)
 		if err != nil {
 			return []string{}, err
 		}
diff --git a/pkg/cmd/util_sources.go b/pkg/cmd/util_sources.go
index fc9e624..4765535 100644
--- a/pkg/cmd/util_sources.go
+++ b/pkg/cmd/util_sources.go
@@ -140,7 +140,7 @@ func ResolveSources(ctx context.Context, locations []string, compress bool) ([]S
 					Compress: compress,
 				}
 
-				content, err := loadContentGitHub(u)
+				content, err := loadContentGitHub(ctx, u)
 				if err != nil {
 					return sources, err
 				}
@@ -156,7 +156,7 @@ func ResolveSources(ctx context.Context, locations []string, compress bool) ([]S
 					Compress: compress,
 				}
 
-				content, err := loadContentHTTP(u)
+				content, err := loadContentHTTP(ctx, u)
 				if err != nil {
 					return sources, err
 				}
@@ -172,7 +172,7 @@ func ResolveSources(ctx context.Context, locations []string, compress bool) ([]S
 					Compress: compress,
 				}
 
-				content, err := loadContentHTTP(u)
+				content, err := loadContentHTTP(ctx, u)
 				if err != nil {
 					return sources, err
 				}
diff --git a/pkg/controller/build/monitor_routine.go b/pkg/controller/build/monitor_routine.go
index aec80b8..cea4d0b 100644
--- a/pkg/controller/build/monitor_routine.go
+++ b/pkg/controller/build/monitor_routine.go
@@ -75,6 +75,8 @@ func (action *monitorRoutineAction) Handle(ctx context.Context, build *v1.Build)
 		}
 		// Start the build asynchronously to avoid blocking the reconciliation loop
 		routines.Store(build.Name, true)
+
+		// nolint: contextcheck
 		go action.runBuild(build)
 
 	case v1.BuildPhaseRunning:
diff --git a/pkg/util/camel/catalog.go b/pkg/util/camel/catalog.go
index 531e791..f47cf61 100644
--- a/pkg/util/camel/catalog.go
+++ b/pkg/util/camel/catalog.go
@@ -124,7 +124,7 @@ func GenerateCatalogCommon(
 	if caCert != nil {
 		trustStoreName := "trust.jks"
 		trustStorePass := jvm.NewKeystorePassword()
-		err := jvm.GenerateKeystore(context.Background(), tmpDir, trustStoreName, trustStorePass, caCert)
+		err := jvm.GenerateKeystore(ctx, tmpDir, trustStoreName, trustStorePass, caCert)
 		if err != nil {
 			return nil, err
 		}

[camel-k] 02/06: chore(lint): remove unused lint configurations

Posted by as...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

astefanutti pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel-k.git

commit bc66d73c01ff2feeb51114431f3f31a44b6b7d1a
Author: Luca Burgazzoli <lb...@gmail.com>
AuthorDate: Wed Nov 24 14:52:33 2021 +0100

    chore(lint): remove unused lint configurations
---
 .golangci.yml | 38 --------------------------------------
 1 file changed, 38 deletions(-)

diff --git a/.golangci.yml b/.golangci.yml
index d9979d7..490d6da 100644
--- a/.golangci.yml
+++ b/.golangci.yml
@@ -59,41 +59,3 @@ linters:
     - contextcheck
     - maligned
 
-issues:
-  exclude-rules:
-    - path: pkg/client/clientset
-      linters:
-        - stylecheck
-        - revive
-        - deadcode
-        - lll
-        - unparam
-        - varcheck
-        - unused
-    - path: pkg/client/informers
-      linters:
-        - stylecheck
-        - revive
-        - deadcode
-        - lll
-        - unparam
-        - varcheck
-        - unused
-    - path: pkg/client/listers
-      linters:
-        - stylecheck
-        - revive
-        - deadcode
-        - lll
-        - unparam
-        - varcheck
-        - unused
-    - path: pkg/resources/resources.go
-      linters:
-        - stylecheck
-        - revive
-        - deadcode
-        - lll
-        - unparam
-        - varcheck
-        - unused