You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@apisix.apache.org by kv...@apache.org on 2021/02/26 16:19:59 UTC

[apisix-ingress-controller] branch master updated: chore: fix spelling (#272)

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

kvn pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/apisix-ingress-controller.git


The following commit(s) were added to refs/heads/master by this push:
     new 0c8f306  chore: fix spelling (#272)
0c8f306 is described below

commit 0c8f306cac9911ababb3c23700ac7ca1efc21833
Author: John Bampton <jb...@users.noreply.github.com>
AuthorDate: Sat Feb 27 02:19:54 2021 +1000

    chore: fix spelling (#272)
---
 CHANGELOG.md                                    | 2 +-
 cmd/ingress/ingress.go                          | 2 +-
 conf/config-default.yaml                        | 4 ++--
 docs/en/latest/CRD-specification.md             | 6 +++---
 docs/en/latest/FAQ.md                           | 2 +-
 docs/en/latest/deployments/ack.md               | 2 +-
 docs/en/latest/deployments/aws.md               | 2 +-
 docs/en/latest/deployments/azure.md             | 4 ++--
 docs/en/latest/deployments/gke.md               | 2 +-
 docs/en/latest/deployments/k3s-rke.md           | 4 ++--
 docs/en/latest/deployments/kubesphere.md        | 2 +-
 docs/en/latest/deployments/minikube.md          | 2 +-
 docs/en/latest/deployments/tke.md               | 4 ++--
 docs/en/latest/development.md                   | 2 +-
 pkg/apisix/upstream.go                          | 2 +-
 pkg/config/config_test.go                       | 2 +-
 pkg/ingress/controller/apisix_upstream.go       | 4 ++--
 pkg/ingress/controller/controller.go            | 2 +-
 pkg/ingress/controller/ingress.go               | 2 +-
 pkg/kube/apisix/apis/config/v1/types.go         | 6 +++---
 pkg/seven/apisix/plugins.go                     | 2 +-
 pkg/seven/state/builder.go                      | 4 ++--
 pkg/types/apisix/v1/types.go                    | 4 ++--
 pkg/version/version.go                          | 2 +-
 samples/deploy/configmap/apisix-ingress-cm.yaml | 2 +-
 test/e2e/README.md                              | 2 +-
 test/e2e/ingress/resourcepushing.go             | 2 +-
 test/e2e/scaffold/k8s.go                        | 2 +-
 test/e2e/testdata/apisix-gw-config.yaml         | 2 +-
 29 files changed, 40 insertions(+), 40 deletions(-)

diff --git a/CHANGELOG.md b/CHANGELOG.md
index 195602e..cd51e7f 100644
--- a/CHANGELOG.md
+++ b/CHANGELOG.md
@@ -81,7 +81,7 @@ This release mainly improve basic features, bugfix and adds test cases.
 
 ## Test case
 
-- Add E2E test enviroment. [#101](https://github.com/apache/apisix-ingress-controller/pull/101)
+- Add E2E test environment. [#101](https://github.com/apache/apisix-ingress-controller/pull/101)
 
 ## Bugfix
 
diff --git a/cmd/ingress/ingress.go b/cmd/ingress/ingress.go
index 213149b..d43f1cd 100644
--- a/cmd/ingress/ingress.go
+++ b/cmd/ingress/ingress.go
@@ -137,7 +137,7 @@ the apisix cluster and others are created`,
 	cmd.PersistentFlags().DurationVar(&cfg.Kubernetes.ResyncInterval.Duration, "resync-interval", time.Minute, "the controller resync (with Kubernetes) interval, the minimum resync interval is 30s")
 	cmd.PersistentFlags().StringSliceVar(&cfg.Kubernetes.AppNamespaces, "app-namespace", []string{config.NamespaceAll}, "namespaces that controller will watch for resources")
 	cmd.PersistentFlags().StringVar(&cfg.Kubernetes.IngressClass, "ingress-class", config.IngressClass, "the class of an Ingress object is set using the field IngressClassName in Kubernetes clusters version v1.18.0 or higher or the annotation \"kubernetes.io/ingress.class\" (deprecated)")
-	cmd.PersistentFlags().StringVar(&cfg.Kubernetes.ElectionID, "election-id", config.IngressAPISIXLeader, "election id used for compaign the controller leader")
+	cmd.PersistentFlags().StringVar(&cfg.Kubernetes.ElectionID, "election-id", config.IngressAPISIXLeader, "election id used for campaign the controller leader")
 	cmd.PersistentFlags().StringVar(&cfg.Kubernetes.IngressVersion, "ingress-version", config.IngressNetworkingV1, "the supported ingress api group version, can be \"networking/v1beta1\" or \"networking/v1\" (for Kubernetes version v1.19.0 or higher)")
 	cmd.PersistentFlags().StringVar(&cfg.APISIX.BaseURL, "apisix-base-url", "", "the base URL for APISIX admin api / manager api")
 	cmd.PersistentFlags().StringVar(&cfg.APISIX.AdminKey, "apisix-admin-key", "", "admin key used for the authorization of APISIX admin api / manager api")
diff --git a/conf/config-default.yaml b/conf/config-default.yaml
index 55547a9..b5d81da 100644
--- a/conf/config-default.yaml
+++ b/conf/config-default.yaml
@@ -28,7 +28,7 @@ log_output: "stderr" # the output file path of error log, default is stderr, whe
                      # programs easily.
 
 http_listen: ":8080"   # the HTTP Server listen address, default is ":8080"
-enable_profiling: true # enable profileing via web interfaces
+enable_profiling: true # enable profiling via web interfaces
                        # host:port/debug/pprof, default is true.
 
 # Kubernetes related configurations.
@@ -40,7 +40,7 @@ kubernetes:
                                        # and the minimal resync interval is 30s.
   app_namespaces: ["*"]                # namespace list that controller will watch for resources,
                                        # by default all namespaces (represented by "*") are watched.
-  election_id: "ingress-apisix-leader" # the election id for the controller leader compaign,
+  election_id: "ingress-apisix-leader" # the election id for the controller leader campaign,
                                        # only the leader will watch and delivery resource changes,
                                        # other instances (as candidates) stand by.
   ingress_class: "apisix"              # The class of an Ingress object is set using the field
diff --git a/docs/en/latest/CRD-specification.md b/docs/en/latest/CRD-specification.md
index 87c8930..a277568 100644
--- a/docs/en/latest/CRD-specification.md
+++ b/docs/en/latest/CRD-specification.md
@@ -162,7 +162,7 @@ With the above settings, Apache APISIX will distributes requests according to th
 
 ### Configuring Health Check
 
-Although Kubelet already provides [probes](https://kubernetes.io/docs/tasks/configure-pod-container/configure-liveness-readiness-startup-probes/#:~:text=The%20kubelet%20uses%20readiness%20probes,removed%20from%20Service%20load%20balancers.) to detect whether pods are healthy, you may still need more powerful health cheak mechanism,
+Although Kubelet already provides [probes](https://kubernetes.io/docs/tasks/configure-pod-container/configure-liveness-readiness-startup-probes/#:~:text=The%20kubelet%20uses%20readiness%20probes,removed%20from%20Service%20load%20balancers.) to detect whether pods are healthy, you may still need more powerful health check mechanism,
 like the passive feedback capability.
 
 ```yaml
@@ -194,7 +194,7 @@ spec:
           - 206
 ```
 
-The above YAML snippet defines a passive health checker to detech the unhealthy state for
+The above YAML snippet defines a passive health checker to detect the unhealthy state for
 endpoints, once there are three consecutive requests with bad status code (one of `500`, `502`, `503`, `504`), the endpoint
 will be set to unhealthy and no requests can be routed there until it's healthy again.
 
@@ -225,7 +225,7 @@ spec:
   retries: 3
 ```
 
-The default connect, read and send timeout are `60s`, which might not proper for some applicartions,
+The default connect, read and send timeout are `60s`, which might not proper for some applications,
 just change them in the `timeout` field.
 
 ```yaml
diff --git a/docs/en/latest/FAQ.md b/docs/en/latest/FAQ.md
index cfe217e..bc621e3 100644
--- a/docs/en/latest/FAQ.md
+++ b/docs/en/latest/FAQ.md
@@ -39,7 +39,7 @@ This is because CRDs are generally declared in the file system, and Apply to ent
 
 So far apisix-ingress-controller doesn't support set admin_key for Apache APISIX, so when you deploy your APISIX cluster, admin_key should be removed from config.
 
-Note since APISIX have two configuration files, the first is config.yaml, which contains the user specified configs, the other is config-default.yaml, which has all default items, config items in these two files will be merged. So admin_key in both files should be removed. You can customize these two configuration files and mount them to APISIX deloyment.
+Note since APISIX have two configuration files, the first is config.yaml, which contains the user specified configs, the other is config-default.yaml, which has all default items, config items in these two files will be merged. So admin_key in both files should be removed. You can customize these two configuration files and mount them to APISIX deployment.
 
 5. Failed to create route with `ApisixRoute`?
 
diff --git a/docs/en/latest/deployments/ack.md b/docs/en/latest/deployments/ack.md
index 6f57d8a..46c6ea7 100644
--- a/docs/en/latest/deployments/ack.md
+++ b/docs/en/latest/deployments/ack.md
@@ -70,6 +70,6 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to Wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to Wait for while until the corresponding pods are running.
 
 Try to create some [resources](../CRD-specification.md) to verify the running status. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/aws.md b/docs/en/latest/deployments/aws.md
index a0b10df..e26ddd2 100644
--- a/docs/en/latest/deployments/aws.md
+++ b/docs/en/latest/deployments/aws.md
@@ -70,7 +70,7 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now open your [EKS console](https://console.aws.amazon.com/eks/home), choosing your cluster and clicking the Workloads tag, you'll see all pods of Apache APISIX, etcd and apisix-ingress-controller are ready.
 
diff --git a/docs/en/latest/deployments/azure.md b/docs/en/latest/deployments/azure.md
index 11d12f3..fc1e50e 100644
--- a/docs/en/latest/deployments/azure.md
+++ b/docs/en/latest/deployments/azure.md
@@ -21,7 +21,7 @@ title: Install Ingress APISIX on Azure AKS
 #
 -->
 
-This document explains how to install Ingress APISIX on [Auzre AKS](https://docs.microsoft.com/en-us/azure/aks/intro-kubernetes#:~:text=Azure%20Kubernetes%20Service%20(AKS)%20makes,managed%20Kubernetes%20cluster%20in%20Azure.&text=The%20Kubernetes%20masters%20are%20managed,clusters%2C%20not%20for%20the%20masters.).
+This document explains how to install Ingress APISIX on [Azure AKS](https://docs.microsoft.com/en-us/azure/aks/intro-kubernetes#:~:text=Azure%20Kubernetes%20Service%20(AKS)%20makes,managed%20Kubernetes%20cluster%20in%20Azure.&text=The%20Kubernetes%20masters%20are%20managed,clusters%2C%20not%20for%20the%20masters.).
 
 ## Prerequisites
 
@@ -70,6 +70,6 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now try to create some [resources](../CRD-specification.md) to verify the running status. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/gke.md b/docs/en/latest/deployments/gke.md
index 55730bd..a17943a 100644
--- a/docs/en/latest/deployments/gke.md
+++ b/docs/en/latest/deployments/gke.md
@@ -70,6 +70,6 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now try to create some [resources](../CRD-specification.md) to verify the running status. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/k3s-rke.md b/docs/en/latest/deployments/k3s-rke.md
index c29cda0..df7e151 100644
--- a/docs/en/latest/deployments/k3s-rke.md
+++ b/docs/en/latest/deployments/k3s-rke.md
@@ -75,8 +75,8 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
 
 *If you are using K3S, the default kubeconfig file is in /etc/rancher/k3s and root permission may required.*
 
-The admin key used in abovementioned commands is the default one, if you change the admin key configuration when you deployed APISIX, please remember to change it here.
+The admin key used in above mentioned commands is the default one, if you change the admin key configuration when you deployed APISIX, please remember to change it here.
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now try to create some [resources](../CRD-specification.md) to verify the running status. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/kubesphere.md b/docs/en/latest/deployments/kubesphere.md
index 00df343..22dcb6a 100644
--- a/docs/en/latest/deployments/kubesphere.md
+++ b/docs/en/latest/deployments/kubesphere.md
@@ -70,6 +70,6 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
 
 The admin key used above is the default one. If you change the admin key configuration when you deployed APISIX, please remember to change it here.
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. Wait for the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. Wait for the corresponding pods are running.
 
 Now try to create some [resources](../CRD-specification.md) to verify the running status. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/minikube.md b/docs/en/latest/deployments/minikube.md
index 7703914..cf3bb4e 100644
--- a/docs/en/latest/deployments/minikube.md
+++ b/docs/en/latest/deployments/minikube.md
@@ -62,6 +62,6 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now try to create some [resources](../CRD-specification.md) to verify the running of Ingress APISIX. As a minimalist example, see [proxy-the-httpbin-service](../samples/proxy-the-httpbin-service.md) to learn how to apply resources to drive the apisix-ingress-controller.
diff --git a/docs/en/latest/deployments/tke.md b/docs/en/latest/deployments/tke.md
index b5b1c9c..510920a 100644
--- a/docs/en/latest/deployments/tke.md
+++ b/docs/en/latest/deployments/tke.md
@@ -47,7 +47,7 @@ helm install apisix ./charts/apisix \
 kubectl get service --namespace ingress-apisix
 ```
 
-Please be careful you must configure the `etcd.persistence.size` to multiplese of 10Gi (it's a limitation on TKE), otherwise the [PersistentVolumeClaim](https://kubernetes.io/docs/concepts/storage/persistent-volumes/) creation will fail.
+Please be careful you must configure the `etcd.persistence.size` to multiples of 10Gi (it's a limitation on TKE), otherwise the [PersistentVolumeClaim](https://kubernetes.io/docs/concepts/storage/persistent-volumes/) creation will fail.
 
 Two Service resources were created, one is `apisix-gateway`, which processes the real traffic; another is `apisix-admin`, which acts as the control plane to process all the configuration changes.
 
@@ -73,7 +73,7 @@ helm install apisix-ingress-controller ./charts/apisix-ingress-controller \
   --namespace ingress-apisix
 ```
 
-Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the correspdoning pods are running.
+Change the `image.tag` to the apisix-ingress-controller version that you desire. You have to wait for while until the corresponding pods are running.
 
 Now open your [TKE console](https://console.cloud.tencent.com/tke2/overview), choosing your cluster and clicking the Workloads tag, you'll see all pods of Apache APISIX, etcd and apisix-ingress-controller are ready.
 
diff --git a/docs/en/latest/development.md b/docs/en/latest/development.md
index ddf109a..be05107 100644
--- a/docs/en/latest/development.md
+++ b/docs/en/latest/development.md
@@ -72,7 +72,7 @@ The Dockerfile in this repository is only for development, not for release.
 
 ## Run apisix-ingress-controller locally
 
-We assume all prerequisites abovementioned are met, what's more, since we want to run apisix-ingress-controller in bare-metal environment, please make sure both the proxy service and admin api service of Apache APISIX are exposed outside of the Kubernetes cluster, e.g. configuring them as [NodePort](https://kubernetes.io/docs/concepts/services-networking/service/#nodeport) services.
+We assume all prerequisites above mentioned are met, what's more, since we want to run apisix-ingress-controller in bare-metal environment, please make sure both the proxy service and admin api service of Apache APISIX are exposed outside of the Kubernetes cluster, e.g. configuring them as [NodePort](https://kubernetes.io/docs/concepts/services-networking/service/#nodeport) services.
 
 Let's assume the Admin API service address of Apache APISIX is `http://192.168.65.2:31156`. Next launch the ingress-apisix-controller by the following command.
 
diff --git a/pkg/apisix/upstream.go b/pkg/apisix/upstream.go
index 43f6c68..bb1077a 100644
--- a/pkg/apisix/upstream.go
+++ b/pkg/apisix/upstream.go
@@ -298,7 +298,7 @@ func (u *upstreamClient) Update(ctx context.Context, obj *v1.Upstream) (*v1.Upst
 		return nil, err
 	}
 	if err := u.cluster.cache.InsertUpstream(ups); err != nil {
-		log.Errorf("failed to reflect upstraem update to cache: %s", err)
+		log.Errorf("failed to reflect upstream update to cache: %s", err)
 		return nil, err
 	}
 	return ups, err
diff --git a/pkg/config/config_test.go b/pkg/config/config_test.go
index d32050d..41fd6f4 100644
--- a/pkg/config/config_test.go
+++ b/pkg/config/config_test.go
@@ -63,7 +63,7 @@ func TestNewConfigFromFile(t *testing.T) {
 
 	assert.Equal(t, cfg, newCfg, "bad configuration")
 
-	// We constrcuts yaml data manually instead of using yaml.Marshal since
+	// We constructs yaml data manually instead of using yaml.Marshal since
 	// types.TimeDuration doesn't have a `yaml:",inline"` tag, if we add it,
 	// error ",inline needs a struct value field" will be reported.
 	// I don't know why.
diff --git a/pkg/ingress/controller/apisix_upstream.go b/pkg/ingress/controller/apisix_upstream.go
index 608e1fc..ba116ad 100644
--- a/pkg/ingress/controller/apisix_upstream.go
+++ b/pkg/ingress/controller/apisix_upstream.go
@@ -192,7 +192,7 @@ func (c *apisixUpstreamController) handleSyncErr(obj interface{}, err error) {
 func (c *apisixUpstreamController) onAdd(obj interface{}) {
 	key, err := cache.MetaNamespaceKeyFunc(obj)
 	if err != nil {
-		log.Errorf("found ApisixUpstream resource with bad meta namesapce key: %s", err)
+		log.Errorf("found ApisixUpstream resource with bad meta namespace key: %s", err)
 		return
 	}
 	if !c.controller.namespaceWatching(key) {
@@ -244,7 +244,7 @@ func (c *apisixUpstreamController) OnDelete(obj interface{}) {
 
 	key, err := cache.DeletionHandlingMetaNamespaceKeyFunc(obj)
 	if err != nil {
-		log.Errorf("found ApisixUpstream resource with bad meta namesapce key: %s", err)
+		log.Errorf("found ApisixUpstream resource with bad meta namespace key: %s", err)
 		return
 	}
 	if !c.controller.namespaceWatching(key) {
diff --git a/pkg/ingress/controller/controller.go b/pkg/ingress/controller/controller.go
index 3bf71ff..2fb66ef 100644
--- a/pkg/ingress/controller/controller.go
+++ b/pkg/ingress/controller/controller.go
@@ -78,7 +78,7 @@ type Controller struct {
 	apisixUpstreamInformer cache.SharedIndexInformer
 	apisixUpstreamLister   listersv1.ApisixUpstreamLister
 
-	// resource conrollers
+	// resource controllers
 	endpointsController      *endpointsController
 	ingressController        *ingressController
 	apisixUpstreamController *apisixUpstreamController
diff --git a/pkg/ingress/controller/ingress.go b/pkg/ingress/controller/ingress.go
index bd48e30..fe0f108 100644
--- a/pkg/ingress/controller/ingress.go
+++ b/pkg/ingress/controller/ingress.go
@@ -214,7 +214,7 @@ func (c *ingressController) handleSyncErr(obj interface{}, err error) {
 func (c *ingressController) onAdd(obj interface{}) {
 	key, err := cache.MetaNamespaceKeyFunc(obj)
 	if err != nil {
-		log.Errorf("found ingress resource with bad meta namesapce key: %s", err)
+		log.Errorf("found ingress resource with bad meta namespace key: %s", err)
 		return
 	}
 	if !c.controller.namespaceWatching(key) {
diff --git a/pkg/kube/apisix/apis/config/v1/types.go b/pkg/kube/apisix/apis/config/v1/types.go
index 1edc2af..fe665ab 100644
--- a/pkg/kube/apisix/apis/config/v1/types.go
+++ b/pkg/kube/apisix/apis/config/v1/types.go
@@ -114,7 +114,7 @@ type ApisixUpstreamConfig struct {
 	// +optional
 	Timeout *UpstreamTimeout `json:"timeout,omitempty" yaml:"timeout,omitempty"`
 
-	// The health check configurtions for the upstream.
+	// The health check configurations for the upstream.
 	// +optional
 	HealthCheck *HealthCheck `json:"healthCheck,omitempty" yaml:"healthCheck,omitempty"`
 }
@@ -183,7 +183,7 @@ type ActiveHealthCheckHealthy struct {
 }
 
 // ActiveHealthCheckUnhealthy defines the conditions to judge whether
-// an upstream node is unhealthy with the active mannger.
+// an upstream node is unhealthy with the active manager.
 type ActiveHealthCheckUnhealthy struct {
 	PassiveHealthCheckUnhealthy `json:",inline" yaml:",inline"`
 
@@ -198,7 +198,7 @@ type PassiveHealthCheckHealthy struct {
 }
 
 // PassiveHealthCheckUnhealthy defines the conditions to judge whether
-// an upstream node is unhealthy with the passive mannger.
+// an upstream node is unhealthy with the passive manager.
 type PassiveHealthCheckUnhealthy struct {
 	HTTPCodes    []int         `json:"httpCodes,omitempty" yaml:"httpCodes,omitempty"`
 	HTTPFailures int           `json:"httpFailures,omitempty" yaml:"http_failures,omitempty"`
diff --git a/pkg/seven/apisix/plugins.go b/pkg/seven/apisix/plugins.go
index f8eefc8..f067267 100644
--- a/pkg/seven/apisix/plugins.go
+++ b/pkg/seven/apisix/plugins.go
@@ -16,7 +16,7 @@ package apisix
 
 import "strings"
 
-// ip-restrictio
+// ip-restriction
 type IpRestriction struct {
 	Whitelist []string `json:"whitelist,omitempty"`
 	Blacklist []string `json:"blacklist,omitempty"`
diff --git a/pkg/seven/state/builder.go b/pkg/seven/state/builder.go
index 0e229d3..9265cd9 100644
--- a/pkg/seven/state/builder.go
+++ b/pkg/seven/state/builder.go
@@ -65,9 +65,9 @@ func paddingUpstream(upstream *v1.Upstream, currentUpstream *v1.Upstream) bool {
 	return false
 }
 
-// NewRouteWorkers make routeWrokers group by service per CRD
+// NewRouteWorkers make routeWorkers group by service per CRD
 // 1.make routes group by (1_2_3) it may be a map like map[1_2_3][]Route;
-// 2.route is listenning Event from the ready of 1_2_3;
+// 2.route is listening Event from the ready of 1_2_3;
 func NewRouteWorkers(ctx context.Context,
 	routes []*v1.Route, wg *sync.WaitGroup, errorChan chan CRDStatus) RouteWorkerGroup {
 
diff --git a/pkg/types/apisix/v1/types.go b/pkg/types/apisix/v1/types.go
index f6b8474..638858c 100644
--- a/pkg/types/apisix/v1/types.go
+++ b/pkg/types/apisix/v1/types.go
@@ -206,7 +206,7 @@ type UpstreamPassiveHealthCheckHealthy struct {
 }
 
 // UpstreamActiveHealthCheckUnhealthy defines the conditions to judge whether
-// an upstream node is unhealthy with the active mannger.
+// an upstream node is unhealthy with the active manager.
 // +k8s:deepcopy-gen=true
 type UpstreamActiveHealthCheckUnhealthy struct {
 	UpstreamPassiveHealthCheckUnhealthy `json:",inline" yaml:",inline"`
@@ -215,7 +215,7 @@ type UpstreamActiveHealthCheckUnhealthy struct {
 }
 
 // UpstreamPassiveHealthCheckUnhealthy defines the conditions to judge whether
-// an upstream node is unhealthy with the passive mannger.
+// an upstream node is unhealthy with the passive manager.
 // +k8s:deepcopy-gen=true
 type UpstreamPassiveHealthCheckUnhealthy struct {
 	HTTPStatuses []int   `json:"http_statuses,omitempty" yaml:"http_statuses,omitempty"`
diff --git a/pkg/version/version.go b/pkg/version/version.go
index fc1abf8..f7d5d87 100644
--- a/pkg/version/version.go
+++ b/pkg/version/version.go
@@ -36,7 +36,7 @@ func Short() string {
 	return fmt.Sprintf("%s-%s-%s", _buildVersion, _buildGitRevision, _buildGoVersion)
 }
 
-// Long produes a verbose version info with format:
+// Long produces a verbose version info with format:
 // Version: xxx
 // Git SHA: xxx
 // GO Version: xxx
diff --git a/samples/deploy/configmap/apisix-ingress-cm.yaml b/samples/deploy/configmap/apisix-ingress-cm.yaml
index 66338da..f9f04ba 100644
--- a/samples/deploy/configmap/apisix-ingress-cm.yaml
+++ b/samples/deploy/configmap/apisix-ingress-cm.yaml
@@ -33,7 +33,7 @@ data:
                         # programs easily.
 
    http_listen: ":8080"   # the HTTP Server listen address, default is ":8080"
-   enable_profiling: true # enable profileing via web interfaces
+   enable_profiling: true # enable profiling via web interfaces
                           # host:port/debug/pprof, default is true.
 
    # Kubernetes related configurations.
diff --git a/test/e2e/README.md b/test/e2e/README.md
index fed9e9c..5f508a8 100644
--- a/test/e2e/README.md
+++ b/test/e2e/README.md
@@ -33,4 +33,4 @@ a e2e test scaffold is prepared to run test cases easily. The source codes are i
 * Create apisix-ingress-controller deployment in the specified namespace;
 * Create a http server with [kennethreitz/httpbin](https://hub.docker.com/r/kennethreitz/httpbin/) as the upstream.
 
-The abovementioned steps are run before each case starts and all resources will be destroyed after the case finishes.
+The above mentioned steps are run before each case starts and all resources will be destroyed after the case finishes.
diff --git a/test/e2e/ingress/resourcepushing.go b/test/e2e/ingress/resourcepushing.go
index be24f97..a936c45 100644
--- a/test/e2e/ingress/resourcepushing.go
+++ b/test/e2e/ingress/resourcepushing.go
@@ -50,7 +50,7 @@ spec:
 		assert.Nil(ginkgo.GinkgoT(), err, "Checking number of routes")
 		err = s.EnsureNumApisixUpstreamsCreated(1)
 		assert.Nil(ginkgo.GinkgoT(), err, "Checking number of upstreams")
-		assert.Nil(ginkgo.GinkgoT(), s.ScaleHTTPBIN(2), "scaling number of httpbin instancess")
+		assert.Nil(ginkgo.GinkgoT(), s.ScaleHTTPBIN(2), "scaling number of httpbin instances")
 		assert.Nil(ginkgo.GinkgoT(), s.WaitAllHTTPBINPoddsAvailable(), "waiting for all httpbin pods ready")
 		// TODO When ingress controller can feedback the lifecycle of CRDs to the
 		// status field, we can poll it rather than sleeping.
diff --git a/test/e2e/scaffold/k8s.go b/test/e2e/scaffold/k8s.go
index 9c8761c..a8c2509 100644
--- a/test/e2e/scaffold/k8s.go
+++ b/test/e2e/scaffold/k8s.go
@@ -102,7 +102,7 @@ func (s *Scaffold) RemoveResourceByString(yaml string) error {
 }
 
 // CreateResourceFromStringWithNamespace creates resource from a loaded yaml string
-// and sets its namespace to the sepcified one.
+// and sets its namespace to the specified one.
 func (s *Scaffold) CreateResourceFromStringWithNamespace(yaml, namespace string) error {
 	originalNamespace := s.kubectlOptions.Namespace
 	s.kubectlOptions.Namespace = namespace
diff --git a/test/e2e/testdata/apisix-gw-config.yaml b/test/e2e/testdata/apisix-gw-config.yaml
index 649fe58..26d10b6 100644
--- a/test/e2e/testdata/apisix-gw-config.yaml
+++ b/test/e2e/testdata/apisix-gw-config.yaml
@@ -75,7 +75,7 @@ apisix:
       #  If set this, must be a string of length 16. And it will encrypt ssl key with AES-128-CBC
     #  !!! So do not change it after saving your ssl, it can't decrypt the ssl keys have be saved if you change !!
 #  discovery: eureka               # service discovery center
-nginx_config:                     # config for render the template to genarate nginx.conf
+nginx_config:                     # config for render the template to generate nginx.conf
   error_log: "logs/error.log"
   error_log_level: "warn"         # warn,error
   worker_processes: auto