diff --git a/api/swagger-spec/v1.json b/api/swagger-spec/v1.json
index 0eb42575432..f87b425e484 100644
--- a/api/swagger-spec/v1.json
+++ b/api/swagger-spec/v1.json
@@ -11429,7 +11429,7 @@
},
"lastTimestamp": {
"type": "string",
- "description": "the time at which the most recent occurance of this event was recorded"
+ "description": "the time at which the most recent occurrence of this event was recorded"
},
"count": {
"type": "integer",
@@ -11985,7 +11985,7 @@
},
"hostPath": {
"$ref": "v1.HostPathVolumeSource",
- "description": "a HostPath provisioned by a developer or tester; for develment use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath"
+ "description": "a HostPath provisioned by a developer or tester; for development use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath"
},
"glusterfs": {
"$ref": "v1.GlusterfsVolumeSource",
diff --git a/cluster/addons/dns/README.md b/cluster/addons/dns/README.md
index 5009b431f59..20cad420792 100644
--- a/cluster/addons/dns/README.md
+++ b/cluster/addons/dns/README.md
@@ -164,7 +164,7 @@ If you see that, DNS is working correctly.
## How does it work?
SkyDNS depends on etcd for what to serve, but it doesn't really need all of
-what etcd offers (at least not in the way we use it). For simplicty, we run
+what etcd offers (at least not in the way we use it). For simplicity, we run
etcd and SkyDNS together in a pod, and we do not try to link etcd instances
across replicas. A helper container called [kube2sky](kube2sky/) also runs in
the pod and acts a bridge between Kubernetes and SkyDNS. It finds the
diff --git a/cluster/aws/config-default.sh b/cluster/aws/config-default.sh
index 5f938b55527..147864b9c63 100644
--- a/cluster/aws/config-default.sh
+++ b/cluster/aws/config-default.sh
@@ -49,7 +49,7 @@ SERVICE_CLUSTER_IP_RANGE="10.0.0.0/16" # formerly PORTAL_NET
CLUSTER_IP_RANGE="${CLUSTER_IP_RANGE:-10.244.0.0/16}"
MASTER_IP_RANGE="${MASTER_IP_RANGE:-10.246.0.0/24}"
# If set to Elastic IP, master instance will be associated with this IP.
-# If set to auto, a new Elastic IP will be aquired
+# If set to auto, a new Elastic IP will be acquired
# Otherwise amazon-given public ip will be used (it'll change with reboot).
MASTER_RESERVED_IP="${MASTER_RESERVED_IP:-}"
diff --git a/cluster/aws/config-test.sh b/cluster/aws/config-test.sh
index 2a13bbab400..49a1b001628 100755
--- a/cluster/aws/config-test.sh
+++ b/cluster/aws/config-test.sh
@@ -45,7 +45,7 @@ SERVICE_CLUSTER_IP_RANGE="10.0.0.0/16" # formerly PORTAL_NET
CLUSTER_IP_RANGE="${CLUSTER_IP_RANGE:-10.245.0.0/16}"
MASTER_IP_RANGE="${MASTER_IP_RANGE:-10.246.0.0/24}"
# If set to Elastic IP, master instance will be associated with this IP.
-# If set to auto, a new Elastic IP will be aquired
+# If set to auto, a new Elastic IP will be acquired
# Otherwise amazon-given public ip will be used (it'll change with reboot).
MASTER_RESERVED_IP="${MASTER_RESERVED_IP:-}"
diff --git a/cluster/aws/util.sh b/cluster/aws/util.sh
index 7a19dcb82ee..ae6c5c22678 100644
--- a/cluster/aws/util.sh
+++ b/cluster/aws/util.sh
@@ -876,7 +876,7 @@ function kube-up {
# This is a race between instance start and volume attachment. There appears to be no way to start an AWS instance with a volume attached.
# To work around this, we wait for volume to be ready in setup-master-pd.sh
- echo "Attaching peristent data volume (${MASTER_DISK_ID}) to master"
+ echo "Attaching persistent data volume (${MASTER_DISK_ID}) to master"
$AWS_CMD attach-volume --volume-id ${MASTER_DISK_ID} --device /dev/sdb --instance-id ${master_id}
sleep 10
diff --git a/cluster/common.sh b/cluster/common.sh
index 683f55922ee..e42a1b61cd6 100755
--- a/cluster/common.sh
+++ b/cluster/common.sh
@@ -172,7 +172,7 @@ function get-kubeconfig-bearertoken() {
}
# Sets KUBE_VERSION variable to the version passed in as an argument, or if argument is
-# latest_stable, latest_release, or latest_ci fetches and sets the correponding version number
+# latest_stable, latest_release, or latest_ci fetches and sets the corresponding version number
#
# Args:
# $1 version string from command line
diff --git a/cluster/gce/util.sh b/cluster/gce/util.sh
index 6d5119eb2b9..b41a754a3a5 100755
--- a/cluster/gce/util.sh
+++ b/cluster/gce/util.sh
@@ -425,7 +425,7 @@ function create-node-template {
}
# Robustly try to add metadata on an instance.
-# $1: The name of the instace.
+# $1: The name of the instance.
# $2...$n: The metadata key=value pairs to add.
function add-instance-metadata {
local -r instance=$1
diff --git a/cluster/juju/charms/trusty/kubernetes-master/unit_tests/test_install.py b/cluster/juju/charms/trusty/kubernetes-master/unit_tests/test_install.py
index b34748a6766..aa54f369cd3 100644
--- a/cluster/juju/charms/trusty/kubernetes-master/unit_tests/test_install.py
+++ b/cluster/juju/charms/trusty/kubernetes-master/unit_tests/test_install.py
@@ -39,7 +39,7 @@ class TestInstallHook():
pmock.return_value.write_lines.assert_called_with(['line1', 'line2',
'test1', 'test2'])
- def test_update_rc_files_with_nonexistant_path(self):
+ def test_update_rc_files_with_nonexistent_path(self):
"""
Test an unhappy path if the bashrc/users do not exist.
"""
diff --git a/cluster/juju/charms/trusty/kubernetes/hooks/start b/cluster/juju/charms/trusty/kubernetes/hooks/start
index d8e63394372..9a5833242a0 100755
--- a/cluster/juju/charms/trusty/kubernetes/hooks/start
+++ b/cluster/juju/charms/trusty/kubernetes/hooks/start
@@ -3,7 +3,7 @@
set -ex
# Start is guaranteed to be called once when after the unit is installed
-# *AND* once everytime a machine is rebooted.
+# *AND* once every time a machine is rebooted.
if [ ! -f $CHARM_DIR/.unit-state ]
then
diff --git a/cluster/juju/return-node-ips.py b/cluster/juju/return-node-ips.py
index 5a6a7955a44..4e5e39c8a94 100755
--- a/cluster/juju/return-node-ips.py
+++ b/cluster/juju/return-node-ips.py
@@ -16,7 +16,7 @@
import json
import sys
-# This script helps parse out the private IP addreses from the
+# This script helps parse out the private IP addresses from the
# `juju run` command's JSON object, see cluster/juju/util.sh
if len(sys.argv) > 1:
diff --git a/cluster/juju/util.sh b/cluster/juju/util.sh
index 7930434ec5a..20c024856b5 100755
--- a/cluster/juju/util.sh
+++ b/cluster/juju/util.sh
@@ -135,7 +135,7 @@ function sleep-status() {
# sleep because we cannot get the status back of where the minions are in the deploy phase
# thanks to a generic "started" state and our service not actually coming online until the
- # minions have recieved the binary from the master distribution hub during relations
+ # minions have received the binary from the master distribution hub during relations
echo "Sleeping an additional minute to allow the cluster to settle"
sleep 60
}
diff --git a/cluster/libvirt-coreos/util.sh b/cluster/libvirt-coreos/util.sh
index 828adf995ee..07954c5f4dd 100644
--- a/cluster/libvirt-coreos/util.sh
+++ b/cluster/libvirt-coreos/util.sh
@@ -296,7 +296,7 @@ function kube-push-internal {
local)
kube-push-local;;
*)
- echo "The only known push methods are \"release\" to use the relase tarball or \"local\" to use the binaries built by make. KUBE_PUSH is set \"$KUBE_PUSH\"" >&2
+ echo "The only known push methods are \"release\" to use the release tarball or \"local\" to use the binaries built by make. KUBE_PUSH is set \"$KUBE_PUSH\"" >&2
return 1;;
esac
}
diff --git a/cluster/mesos/docker/util.sh b/cluster/mesos/docker/util.sh
index a181aeffa1c..7592ebbbe9b 100644
--- a/cluster/mesos/docker/util.sh
+++ b/cluster/mesos/docker/util.sh
@@ -218,7 +218,7 @@ function validate-cluster {
echo "Validating ${KUBERNETES_PROVIDER} cluster" 1>&2
# Do not validate cluster size. There will be zero k8s minions until a pod is created.
- # TODO(karlkfi): use componentstatuses or equivelent when it supports non-localhost core components
+ # TODO(karlkfi): use componentstatuses or equivalent when it supports non-localhost core components
# Validate immediate cluster reachability and responsiveness
echo "KubeDNS: $(cluster::mesos::docker::addon_status 'kube-dns')"
diff --git a/cluster/saltbase/salt/kube-addons/kube-addon-update.sh b/cluster/saltbase/salt/kube-addons/kube-addon-update.sh
index 174887a6ac5..c04815ff210 100755
--- a/cluster/saltbase/salt/kube-addons/kube-addon-update.sh
+++ b/cluster/saltbase/salt/kube-addons/kube-addon-update.sh
@@ -25,7 +25,7 @@
# LIMITATIONS
# 1. controllers are not updated unless their name is changed
# 3. Services will not be updated unless their name is changed,
-# but for services we acually want updates without name change.
+# but for services we actually want updates without name change.
# 4. Json files are not handled at all. Currently addons must be
# in yaml files
# 5. exit code is probably not always correct (I haven't checked
diff --git a/cluster/saltbase/salt/kube-master-addons/init.sls b/cluster/saltbase/salt/kube-master-addons/init.sls
index acade6d2440..9ae0a8d3396 100644
--- a/cluster/saltbase/salt/kube-master-addons/init.sls
+++ b/cluster/saltbase/salt/kube-master-addons/init.sls
@@ -6,7 +6,7 @@
- mode: 755
# Used to restart kube-master-addons service each time salt is run
-# Actually, it doens't work (the service is not restarted),
+# Actually, it does not work (the service is not restarted),
# but master-addon service always terminates after it does it job,
# so it is (usually) not running and it will be started when
# salt is run.
diff --git a/cluster/ubuntu/util.sh b/cluster/ubuntu/util.sh
index b3bc68c8b77..9bbd762f43d 100755
--- a/cluster/ubuntu/util.sh
+++ b/cluster/ubuntu/util.sh
@@ -35,7 +35,7 @@ function test-build-release {
"${KUBE_ROOT}/build/release.sh"
}
-# From user input set the necessary k8s and etcd configuration infomation
+# From user input set the necessary k8s and etcd configuration information
function setClusterInfo() {
# Initialize MINION_IPS in setClusterInfo function
# MINION_IPS is defined as a global variable, and is concatenated with other nodeIP
diff --git a/cmd/kube-apiserver/app/server.go b/cmd/kube-apiserver/app/server.go
index 4e8416b2fe9..3801a290017 100644
--- a/cmd/kube-apiserver/app/server.go
+++ b/cmd/kube-apiserver/app/server.go
@@ -479,7 +479,7 @@ func (s *APIServer) Run(_ []string) error {
}
// err == systemd.SdNotifyNoSocket when not running on a systemd system
if err := systemd.SdNotify("READY=1\n"); err != nil && err != systemd.SdNotifyNoSocket {
- glog.Errorf("Unable to send systemd daemon sucessful start message: %v\n", err)
+ glog.Errorf("Unable to send systemd daemon successful start message: %v\n", err)
}
if err := secureServer.ListenAndServeTLS(s.TLSCertFile, s.TLSPrivateKeyFile); err != nil {
glog.Errorf("Unable to listen for secure (%v); will try again.", err)
@@ -497,7 +497,7 @@ func (s *APIServer) Run(_ []string) error {
if secureLocation == "" {
// err == systemd.SdNotifyNoSocket when not running on a systemd system
if err := systemd.SdNotify("READY=1\n"); err != nil && err != systemd.SdNotifyNoSocket {
- glog.Errorf("Unable to send systemd daemon sucessful start message: %v\n", err)
+ glog.Errorf("Unable to send systemd daemon successful start message: %v\n", err)
}
}
glog.Infof("Serving insecurely on %s", insecureLocation)
diff --git a/cmd/kube-controller-manager/app/controllermanager.go b/cmd/kube-controller-manager/app/controllermanager.go
index f6f190b0d7b..3522e423895 100644
--- a/cmd/kube-controller-manager/app/controllermanager.go
+++ b/cmd/kube-controller-manager/app/controllermanager.go
@@ -125,7 +125,7 @@ func (s *CMServer) AddFlags(fs *pflag.FlagSet) {
fs.IntVar(&s.DeletingPodsBurst, "deleting-pods-burst", 10, "Number of nodes on which pods are bursty deleted in case of node failure. For more details look into RateLimiter.")
fs.IntVar(&s.RegisterRetryCount, "register-retry-count", s.RegisterRetryCount, ""+
"The number of retries for initial node registration. Retry interval equals node-sync-period.")
- fs.MarkDeprecated("register-retry-count", "This flag is currenty no-op and will be deleted.")
+ fs.MarkDeprecated("register-retry-count", "This flag is currently no-op and will be deleted.")
fs.DurationVar(&s.NodeMonitorGracePeriod, "node-monitor-grace-period", 40*time.Second,
"Amount of time which we allow running Node to be unresponsive before marking it unhealty. "+
"Must be N times more than kubelet's nodeStatusUpdateFrequency, "+
diff --git a/contrib/ansible/roles/kubernetes-addons/files/kube-addon-update.sh b/contrib/ansible/roles/kubernetes-addons/files/kube-addon-update.sh
index 93f0469b409..c7fba2f917b 100755
--- a/contrib/ansible/roles/kubernetes-addons/files/kube-addon-update.sh
+++ b/contrib/ansible/roles/kubernetes-addons/files/kube-addon-update.sh
@@ -25,7 +25,7 @@
# LIMITATIONS
# 1. controllers are not updated unless their name is changed
# 3. Services will not be updated unless their name is changed,
-# but for services we acually want updates without name change.
+# but for services we actually want updates without name change.
# 4. Json files are not handled at all. Currently addons must be
# in yaml files
# 5. exit code is probably not always correct (I haven't checked
diff --git a/contrib/ansible/roles/kubernetes/defaults/main.yml b/contrib/ansible/roles/kubernetes/defaults/main.yml
index 8d9a1f7e6fe..58def0c4bf8 100644
--- a/contrib/ansible/roles/kubernetes/defaults/main.yml
+++ b/contrib/ansible/roles/kubernetes/defaults/main.yml
@@ -25,7 +25,7 @@ kube_token_dir: "{{ kube_config_dir }}/tokens"
kube_manifest_dir: "{{ kube_config_dir }}/manifests"
# This is the group that the cert creation scripts chgrp the
-# cert files to. Not really changable...
+# cert files to. Not really changeable...
kube_cert_group: kube-cert
# Internal DNS domain name.
diff --git a/contrib/diurnal/time.go b/contrib/diurnal/time.go
index 6abcfbe591f..d32b11d712f 100644
--- a/contrib/diurnal/time.go
+++ b/contrib/diurnal/time.go
@@ -182,7 +182,7 @@ func parseTimeISO8601(s string) (time.Time, error) {
theTime.offMinute = v
s = s[2:]
default:
- return time.Time{}, errors.New("an unknown error occured")
+ return time.Time{}, errors.New("an unknown error occurred")
}
state++
}
diff --git a/contrib/for-demos/proxy-to-service/Dockerfile b/contrib/for-demos/proxy-to-service/Dockerfile
index 0ebe1a7a2ad..bd3e4646196 100644
--- a/contrib/for-demos/proxy-to-service/Dockerfile
+++ b/contrib/for-demos/proxy-to-service/Dockerfile
@@ -1,4 +1,4 @@
-# Alpine linux would be great for this, but it's DNS does not use seach paths.
+# Alpine linux would be great for this, but it's DNS does not use search paths.
FROM progrium/busybox
MAINTAINER Tim Hockin "thockin@google.com"
diff --git a/contrib/mesos/docs/ha.md b/contrib/mesos/docs/ha.md
index 055804d4d7d..7cdc6ecb75b 100644
--- a/contrib/mesos/docs/ha.md
+++ b/contrib/mesos/docs/ha.md
@@ -34,7 +34,7 @@ In this case, if there are problems launching a replacement scheduler process th
##### Command Line Arguments
- `--ha` is required to enable scheduler HA and multi-scheduler leader election.
-- `--km_path` or else (`--executor_path` and `--proxy_path`) should reference non-local-file URI's and must be identicial across schedulers.
+- `--km_path` or else (`--executor_path` and `--proxy_path`) should reference non-local-file URI's and must be identical across schedulers.
If you have HDFS installed on your slaves then you can specify HDFS URI locations for the binaries:
diff --git a/contrib/mesos/pkg/executor/executor_test.go b/contrib/mesos/pkg/executor/executor_test.go
index a4c40bc7e65..0572067f0e1 100644
--- a/contrib/mesos/pkg/executor/executor_test.go
+++ b/contrib/mesos/pkg/executor/executor_test.go
@@ -263,7 +263,7 @@ func TestExecutorRegister(t *testing.T) {
}
// TestExecutorDisconnect ensures that the executor thinks that it is not
-// connected after a call to Disconnected has occured.
+// connected after a call to Disconnected has occurred.
func TestExecutorDisconnect(t *testing.T) {
mockDriver := &MockExecutorDriver{}
executor := NewTestKubernetesExecutor()
@@ -346,7 +346,7 @@ func TestExecutorLaunchAndKillTask(t *testing.T) {
select {
case <-updates:
case <-time.After(time.Second):
- t.Fatalf("Executor should send an intial update on Registration")
+ t.Fatalf("Executor should send an initial update on Registration")
}
pod := NewTestPod(1)
diff --git a/contrib/mesos/pkg/queue/interface.go b/contrib/mesos/pkg/queue/interface.go
index 143816c90de..de10a47904a 100644
--- a/contrib/mesos/pkg/queue/interface.go
+++ b/contrib/mesos/pkg/queue/interface.go
@@ -58,7 +58,7 @@ type FIFO interface {
// Pop waits until an item is ready and returns it. If multiple items are
// ready, they are returned in the order in which they were added/updated.
// The item is removed from the queue (and the store) before it is returned,
- // so if you don't succesfully process it, you need to add it back with Add().
+ // so if you don't successfully process it, you need to add it back with Add().
Pop() interface{}
// Await attempts to Pop within the given interval; upon success the non-nil
diff --git a/contrib/mesos/pkg/scheduler/plugin.go b/contrib/mesos/pkg/scheduler/plugin.go
index 6a6bd1e2e1d..ac03cc1336f 100644
--- a/contrib/mesos/pkg/scheduler/plugin.go
+++ b/contrib/mesos/pkg/scheduler/plugin.go
@@ -350,7 +350,7 @@ func (k *kubeScheduler) doSchedule(task *podtask.T, err error) (string, error) {
return "", fmt.Errorf("task.offer assignment must be idempotent, task %+v: offer %+v", task, offer)
}
- // write resource limits into the pod spec which is transfered to the executor. From here
+ // write resource limits into the pod spec which is transferred to the executor. From here
// on we can expect that the pod spec of a task has proper limits for CPU and memory.
// TODO(sttts): For a later separation of the kubelet and the executor also patch the pod on the apiserver
if unlimitedCPU := mresource.LimitPodCPU(&task.Pod, k.defaultContainerCPULimit); unlimitedCPU {
diff --git a/contrib/prometheus/README.md b/contrib/prometheus/README.md
index a85a47d2437..9985c038645 100644
--- a/contrib/prometheus/README.md
+++ b/contrib/prometheus/README.md
@@ -52,7 +52,7 @@ This is a v1 api based, containerized prometheus ReplicationController, which sc
1. Use kubectl to handle auth & proxy the kubernetes API locally, emulating the old KUBERNETES_RO service.
-1. The list of services to be monitored is passed as a command line aguments in
+1. The list of services to be monitored is passed as a command line arguments in
the yaml file.
1. The startup scripts assumes that each service T will have
diff --git a/contrib/service-loadbalancer/README.md b/contrib/service-loadbalancer/README.md
index 836eb4d3fa9..15a6fb4c04f 100644
--- a/contrib/service-loadbalancer/README.md
+++ b/contrib/service-loadbalancer/README.md
@@ -191,7 +191,7 @@ $ mysql -u root -ppassword --host 104.197.63.17 --port 3306 -e 'show databases;'
### Troubleshooting:
- If you can curl or netcat the endpoint from the pod (with kubectl exec) and not from the node, you have not specified hostport and containerport.
- If you can hit the ips from the node but not from your machine outside the cluster, you have not opened firewall rules for the right network.
-- If you can't hit the ips from within the container, either haproxy or the service_loadbalacer script is not runing.
+- If you can't hit the ips from within the container, either haproxy or the service_loadbalacer script is not running.
1. Use ps in the pod
2. sudo restart haproxy in the pod
3. cat /etc/haproxy/haproxy.cfg in the pod
diff --git a/contrib/service-loadbalancer/service_loadbalancer_test.go b/contrib/service-loadbalancer/service_loadbalancer_test.go
index a744682cd1b..23977cde9bc 100644
--- a/contrib/service-loadbalancer/service_loadbalancer_test.go
+++ b/contrib/service-loadbalancer/service_loadbalancer_test.go
@@ -141,7 +141,7 @@ func TestGetServices(t *testing.T) {
{Port: 20, TargetPort: util.NewIntOrStringFromInt(ports[1])},
}
- // 2 services targetting the same endpoints, one of which is declared as a tcp service.
+ // 2 services targeting the same endpoints, one of which is declared as a tcp service.
svc1 := getService(servicePorts)
svc2 := getService(servicePorts)
endpoints := []*api.Endpoints{
diff --git a/docs/admin/cluster-large.md b/docs/admin/cluster-large.md
index 28b83e5bbb1..c8febe78e16 100644
--- a/docs/admin/cluster-large.md
+++ b/docs/admin/cluster-large.md
@@ -88,7 +88,7 @@ To avoid running into cluster addon resource issues, when creating a cluster wit
* [Kibana](http://releases.k8s.io/HEAD/cluster/addons/fluentd-elasticsearch/kibana-controller.yaml)
* Scale number of replicas for the following addons, if used, along with the size of cluster (there are multiple replicas of each so increasing replicas should help handle increased load, but, since load per replica also increases slightly, also consider increasing CPU/memory limits):
* [elasticsearch](http://releases.k8s.io/HEAD/cluster/addons/fluentd-elasticsearch/es-controller.yaml)
-* Increase memory and CPU limits sligthly for each of the following addons, if used, along with the size of cluster (there is one replica per node but CPU/memory usage increases slightly along with cluster load/size as well):
+* Increase memory and CPU limits slightly for each of the following addons, if used, along with the size of cluster (there is one replica per node but CPU/memory usage increases slightly along with cluster load/size as well):
* [FluentD with ElasticSearch Plugin](http://releases.k8s.io/HEAD/cluster/saltbase/salt/fluentd-es/fluentd-es.yaml)
* [FluentD with GCP Plugin](http://releases.k8s.io/HEAD/cluster/saltbase/salt/fluentd-gcp/fluentd-gcp.yaml)
diff --git a/docs/admin/cluster-management.md b/docs/admin/cluster-management.md
index d2149e9354d..fcc33b8ff24 100644
--- a/docs/admin/cluster-management.md
+++ b/docs/admin/cluster-management.md
@@ -35,7 +35,7 @@ Documentation for other releases can be found at
This document describes several topics related to the lifecycle of a cluster: creating a new cluster,
upgrading your cluster's
-master and worker nodes, performing node maintainence (e.g. kernel upgrades), and upgrading the Kubernetes API version of a
+master and worker nodes, performing node maintenance (e.g. kernel upgrades), and upgrading the Kubernetes API version of a
running cluster.
## Creating and configuring a Cluster
@@ -132,7 +132,7 @@ For pods with a replication controller, the pod will eventually be replaced by a
For pods with no replication controller, you need to bring up a new copy of the pod, and assuming it is not part of a service, redirect clients to it.
-Perform maintainence work on the node.
+Perform maintenance work on the node.
Make the node schedulable again:
diff --git a/docs/admin/etcd.md b/docs/admin/etcd.md
index 00322598b61..44a1824c548 100644
--- a/docs/admin/etcd.md
+++ b/docs/admin/etcd.md
@@ -41,7 +41,7 @@ objects.
Access Control: give *only* kube-apiserver read/write access to etcd. You do not
want apiserver's etcd exposed to every node in your cluster (or worse, to the
-internet at large), because access to etcd is equivilent to root in your
+internet at large), because access to etcd is equivalent to root in your
cluster.
Data Reliability: for reasonable safety, either etcd needs to be run as a
diff --git a/docs/api-reference/definitions.html b/docs/api-reference/definitions.html
index 958d2e52dd9..babdce90c32 100644
--- a/docs/api-reference/definitions.html
+++ b/docs/api-reference/definitions.html
@@ -4224,7 +4224,7 @@ span.icon > [class^="icon-"], span.icon > [class*=" icon-"] { cursor: default; }
hostPath |
-a HostPath provisioned by a developer or tester; for develment use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath |
+a HostPath provisioned by a developer or tester; for development use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath |
false |
v1.HostPathVolumeSource |
|
@@ -5099,7 +5099,7 @@ span.icon > [class^="icon-"], span.icon > [class*=" icon-"] { cursor: default; }
lastTimestamp |
-the time at which the most recent occurance of this event was recorded |
+the time at which the most recent occurrence of this event was recorded |
false |
string |
|
diff --git a/docs/devel/development.md b/docs/devel/development.md
index 454632934b1..2929f281035 100644
--- a/docs/devel/development.md
+++ b/docs/devel/development.md
@@ -87,7 +87,7 @@ Note: If you have write access to the main repository at github.com/GoogleCloudP
git remote set-url --push upstream no_push
```
-### Commiting changes to your fork
+### Committing changes to your fork
```sh
git commit
diff --git a/docs/devel/making-release-notes.md b/docs/devel/making-release-notes.md
index d4ec6ccf372..1efab1ac7da 100644
--- a/docs/devel/making-release-notes.md
+++ b/docs/devel/making-release-notes.md
@@ -40,7 +40,7 @@ This documents the process for making release notes for a release.
Find the most-recent PR that was merged with the previous .0 release. Remember this as $LASTPR.
_TODO_: Figure out a way to record this somewhere to save the next release engineer time.
-Find the most-recent PR that was merged with the current .0 release. Remeber this as $CURRENTPR.
+Find the most-recent PR that was merged with the current .0 release. Remember this as $CURRENTPR.
### 2) Run the release-notes tool
diff --git a/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-etcd-node-template.yml b/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-etcd-node-template.yml
index cf75025ee1a..4cbb480e531 100644
--- a/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-etcd-node-template.yml
+++ b/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-etcd-node-template.yml
@@ -1,4 +1,4 @@
-## This file is used as input to deployment script, which ammends it as needed.
+## This file is used as input to deployment script, which amends it as needed.
## More specifically, we need to add peer hosts for each but the elected peer.
coreos:
diff --git a/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-main-nodes-template.yml b/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-main-nodes-template.yml
index 1e4305133a2..340c804139f 100644
--- a/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-main-nodes-template.yml
+++ b/docs/getting-started-guides/coreos/azure/cloud_config_templates/kubernetes-cluster-main-nodes-template.yml
@@ -1,4 +1,4 @@
-## This file is used as input to deployment script, which ammends it as needed.
+## This file is used as input to deployment script, which amends it as needed.
## More specifically, we need to add environment files for as many nodes as we
## are going to deploy.
diff --git a/docs/getting-started-guides/docker-multinode.md b/docs/getting-started-guides/docker-multinode.md
index 60787ac7105..4ca6e1c2590 100644
--- a/docs/getting-started-guides/docker-multinode.md
+++ b/docs/getting-started-guides/docker-multinode.md
@@ -87,7 +87,7 @@ cd kubernetes/cluster/docker-multinode
`Master done!`
-See [here](docker-multinode/master.md) for detailed instructions explaination.
+See [here](docker-multinode/master.md) for detailed instructions explanation.
## Adding a worker node
@@ -104,7 +104,7 @@ cd kubernetes/cluster/docker-multinode
`Worker done!`
-See [here](docker-multinode/worker.md) for detailed instructions explaination.
+See [here](docker-multinode/worker.md) for detailed instructions explanation.
## Testing your cluster
diff --git a/docs/man/man1/kubectl-namespace.1 b/docs/man/man1/kubectl-namespace.1
index 94b04c52a9e..169b5219a3a 100644
--- a/docs/man/man1/kubectl-namespace.1
+++ b/docs/man/man1/kubectl-namespace.1
@@ -3,7 +3,7 @@
.SH NAME
.PP
-kubectl namespace \- SUPERCEDED: Set and view the current Kubernetes namespace
+kubectl namespace \- SUPERSEDED: Set and view the current Kubernetes namespace
.SH SYNOPSIS
@@ -13,10 +13,10 @@ kubectl namespace \- SUPERCEDED: Set and view the current Kubernetes namespace
.SH DESCRIPTION
.PP
-SUPERCEDED: Set and view the current Kubernetes namespace scope for command line requests.
+SUPERSEDED: Set and view the current Kubernetes namespace scope for command line requests.
.PP
-namespace has been superceded by the context.namespace field of .kubeconfig files. See 'kubectl config set\-context \-\-help' for more details.
+namespace has been superseded by the context.namespace field of .kubeconfig files. See 'kubectl config set\-context \-\-help' for more details.
.SH OPTIONS
diff --git a/docs/user-guide/kubectl/kubectl.md b/docs/user-guide/kubectl/kubectl.md
index f1e4c1d8464..b0d149aa692 100644
--- a/docs/user-guide/kubectl/kubectl.md
+++ b/docs/user-guide/kubectl/kubectl.md
@@ -91,7 +91,7 @@ kubectl
* [kubectl get](kubectl_get.md) - Display one or many resources
* [kubectl label](kubectl_label.md) - Update the labels on a resource
* [kubectl logs](kubectl_logs.md) - Print the logs for a container in a pod.
-* [kubectl namespace](kubectl_namespace.md) - SUPERCEDED: Set and view the current Kubernetes namespace
+* [kubectl namespace](kubectl_namespace.md) - SUPERSEDED: Set and view the current Kubernetes namespace
* [kubectl patch](kubectl_patch.md) - Update field(s) of a resource by stdin.
* [kubectl port-forward](kubectl_port-forward.md) - Forward one or more local ports to a pod.
* [kubectl proxy](kubectl_proxy.md) - Run a proxy to the Kubernetes API server
diff --git a/docs/user-guide/kubectl/kubectl_namespace.md b/docs/user-guide/kubectl/kubectl_namespace.md
index cba9f605012..6e4465758a0 100644
--- a/docs/user-guide/kubectl/kubectl_namespace.md
+++ b/docs/user-guide/kubectl/kubectl_namespace.md
@@ -33,14 +33,14 @@ Documentation for other releases can be found at
## kubectl namespace
-SUPERCEDED: Set and view the current Kubernetes namespace
+SUPERSEDED: Set and view the current Kubernetes namespace
### Synopsis
-SUPERCEDED: Set and view the current Kubernetes namespace scope for command line requests.
+SUPERSEDED: Set and view the current Kubernetes namespace scope for command line requests.
-namespace has been superceded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details.
+namespace has been superseded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details.
```
diff --git a/docs/user-guide/secrets.md b/docs/user-guide/secrets.md
index d78ca91958b..3a0f73f0bd3 100644
--- a/docs/user-guide/secrets.md
+++ b/docs/user-guide/secrets.md
@@ -160,7 +160,7 @@ See another example of creating a secret and a pod that consumes that secret in
### Manually specifying an imagePullSecret
-Use of imagePullSecrets is desribed in the [images documentation](images.md#specifying-imagepullsecrets-on-a-pod)
+Use of imagePullSecrets is described in the [images documentation](images.md#specifying-imagepullsecrets-on-a-pod)
### Automatic use of Manually Created Secrets
diff --git a/examples/cassandra/image/cassandra.yaml b/examples/cassandra/image/cassandra.yaml
index f409e82025b..c5df4cadf0e 100644
--- a/examples/cassandra/image/cassandra.yaml
+++ b/examples/cassandra/image/cassandra.yaml
@@ -506,7 +506,7 @@ tombstone_failure_threshold: 100000
# Increase if your rows are large, or if you have a very large
# number of rows per partition. The competing goals are these:
# 1) a smaller granularity means more index entries are generated
-# and looking up rows withing the partition by collation column
+# and looking up rows within the partition by collation column
# is faster
# 2) but, Cassandra will keep the collation index in memory for hot
# rows (as part of the key cache), so a larger granularity means
diff --git a/examples/high-availability/provision.sh b/examples/high-availability/provision.sh
index dacfebdd924..0cd7c943d4b 100755
--- a/examples/high-availability/provision.sh
+++ b/examples/high-availability/provision.sh
@@ -90,7 +90,7 @@ function write_api_server_config {
mkdir -p -m 777 /srv/kubernetes/
### We will move files back and forth between the /srv/kube.. directory.
- ### That is how we modulate leader. Each node will continously either
+ ### That is how we modulate leader. Each node will continuously either
### ensure that the manifests are in this dir, or else, are in the kubelet manifest dir.
cp /vagrant/kube-scheduler.manifest /vagrant/kube-controller-manager.manifest /srv/kubernetes
diff --git a/examples/k8petstore/dev/README b/examples/k8petstore/dev/README
index 25c8d7b143e..02ec1e4fa1c 100644
--- a/examples/k8petstore/dev/README
+++ b/examples/k8petstore/dev/README
@@ -20,7 +20,7 @@ go get
go run PetStoreBook.go
```
-Once the app works the way you want it to, test it in the vagrant recipe below. This will gaurantee that you're local environment isn't doing something that breaks the containers at the versioning level.
+Once the app works the way you want it to, test it in the vagrant recipe below. This will guarantee that you're local environment isn't doing something that breaks the containers at the versioning level.
### Testing
diff --git a/hack/e2e.go b/hack/e2e.go
index 7185fd2fcbf..f8614028de1 100644
--- a/hack/e2e.go
+++ b/hack/e2e.go
@@ -318,7 +318,7 @@ func printPrefixedLines(prefix, s string) {
}
// returns either "", or a list of args intended for appending with the
-// kubectl command (begining with a space).
+// kubectl command (beginning with a space).
func kubectlArgs() string {
if *checkVersionSkew {
return " --match-server-version"
diff --git a/hack/gen-swagger-doc/example-output/definitions.html b/hack/gen-swagger-doc/example-output/definitions.html
index 562b43c7e58..09691c8c0ac 100644
--- a/hack/gen-swagger-doc/example-output/definitions.html
+++ b/hack/gen-swagger-doc/example-output/definitions.html
@@ -4217,7 +4217,7 @@ span.icon > [class^="icon-"], span.icon > [class*=" icon-"] { cursor: default; }
hostPath |
-a HostPath provisioned by a developer or tester; for develment use only; see http://releases.k8s.io/HEAD/docs/volumes.md#hostpath |
+a HostPath provisioned by a developer or tester; for development use only; see http://releases.k8s.io/HEAD/docs/volumes.md#hostpath |
false |
v1.HostPathVolumeSource |
|
@@ -5092,7 +5092,7 @@ span.icon > [class^="icon-"], span.icon > [class*=" icon-"] { cursor: default; }
lastTimestamp |
-the time at which the most recent occurance of this event was recorded |
+the time at which the most recent occurrence of this event was recorded |
false |
string |
|
diff --git a/hack/run-gendocs.sh b/hack/run-gendocs.sh
index 6b71a7177ae..35c3703a868 100755
--- a/hack/run-gendocs.sh
+++ b/hack/run-gendocs.sh
@@ -47,7 +47,7 @@ kube::util::gen-analytics "${KUBE_ROOT}"
"${mungedocs}" "--root-dir=${KUBE_ROOT}/docs/" && ret=0 || ret=$?
if [[ $ret -eq 1 ]]; then
- echo "${KUBE_ROOT}/docs/ requires manual changes. See preceeding errors."
+ echo "${KUBE_ROOT}/docs/ requires manual changes. See preceding errors."
exit 1
elif [[ $ret -gt 1 ]]; then
echo "Error running mungedocs."
@@ -56,7 +56,7 @@ fi
"${mungedocs}" "--root-dir=${KUBE_ROOT}/examples/" && ret=0 || ret=$?
if [[ $ret -eq 1 ]]; then
- echo "${KUBE_ROOT}/examples/ requires manual changes. See preceeding errors."
+ echo "${KUBE_ROOT}/examples/ requires manual changes. See preceding errors."
exit 1
elif [[ $ret -gt 1 ]]; then
echo "Error running mungedocs."
diff --git a/hooks/boilerplate.py b/hooks/boilerplate.py
index 72fcf9709d6..f04068e545b 100755
--- a/hooks/boilerplate.py
+++ b/hooks/boilerplate.py
@@ -57,7 +57,7 @@ def file_passes(filename, extension, ref, regexs):
if p.search(d):
return False
- # Replace all occurances of the regex "2015|2014" with "YEAR"
+ # Replace all occurrences of the regex "2015|2014" with "YEAR"
p = regexs["date"]
for i, d in enumerate(data):
(data[i], found) = p.subn('YEAR', d)
diff --git a/pkg/api/errors/errors.go b/pkg/api/errors/errors.go
index 890e333496b..4583c188e38 100644
--- a/pkg/api/errors/errors.go
+++ b/pkg/api/errors/errors.go
@@ -34,7 +34,7 @@ const (
StatusTooManyRequests = 429
// HTTP recommendations are for servers to define 5xx error codes
// for scenarios not covered by behavior. In this case, ServerTimeout
- // is an indication that a transient server error has occured and the
+ // is an indication that a transient server error has occurred and the
// client *should* retry, with an optional Retry-After header to specify
// the back off window.
StatusServerTimeout = 504
diff --git a/pkg/api/helpers.go b/pkg/api/helpers.go
index e3100e46b4e..e79e6e202ed 100644
--- a/pkg/api/helpers.go
+++ b/pkg/api/helpers.go
@@ -53,7 +53,7 @@ var Semantic = conversion.EqualitiesOrDie(
// TODO: if we decide it's important, after we drop v1beta1/2, we
// could start comparing format.
//
- // Uninitialized quantities are equivilent to 0 quantities.
+ // Uninitialized quantities are equivalent to 0 quantities.
if a.Amount == nil && b.MilliValue() == 0 {
return true
}
diff --git a/pkg/api/types.go b/pkg/api/types.go
index 429abe5ce21..72be0d37c1d 100644
--- a/pkg/api/types.go
+++ b/pkg/api/types.go
@@ -1808,7 +1808,7 @@ type StatusCause struct {
}
// CauseType is a machine readable value providing more detail about what
-// occured in a status response. An operation may have multiple causes for a
+// occurred in a status response. An operation may have multiple causes for a
// status (whether Failure or Success).
type CauseType string
@@ -1897,7 +1897,7 @@ type Event struct {
// The time at which the event was first recorded. (Time of server receipt is in TypeMeta.)
FirstTimestamp util.Time `json:"firstTimestamp,omitempty"`
- // The time at which the most recent occurance of this event was recorded.
+ // The time at which the most recent occurrence of this event was recorded.
LastTimestamp util.Time `json:"lastTimestamp,omitempty"`
// The number of times this event has occurred.
diff --git a/pkg/api/v1/conversion.go b/pkg/api/v1/conversion.go
index 7ace3ee114d..a61a6252607 100644
--- a/pkg/api/v1/conversion.go
+++ b/pkg/api/v1/conversion.go
@@ -46,7 +46,7 @@ func addConversionFuncs() {
"status.phase",
"spec.nodeName":
return label, value, nil
- // This is for backwards compatability with old v1 clients which send spec.host
+ // This is for backwards compatibility with old v1 clients which send spec.host
case "spec.host":
return "spec.nodeName", value, nil
default:
diff --git a/pkg/api/v1/types.go b/pkg/api/v1/types.go
index 2f8178bc393..10a3e71ec3d 100644
--- a/pkg/api/v1/types.go
+++ b/pkg/api/v1/types.go
@@ -224,7 +224,7 @@ type PersistentVolumeSource struct {
// HostPath represents a directory on the host.
// This is useful for development and testing only.
// on-host storage is not supported in any way.
- HostPath *HostPathVolumeSource `json:"hostPath,omitempty" description:"a HostPath provisioned by a developer or tester; for develment use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath"`
+ HostPath *HostPathVolumeSource `json:"hostPath,omitempty" description:"a HostPath provisioned by a developer or tester; for development use only; see http://releases.k8s.io/HEAD/docs/user-guide/volumes.md#hostpath"`
// Glusterfs represents a Glusterfs volume that is attached to a host and exposed to the pod
Glusterfs *GlusterfsVolumeSource `json:"glusterfs,omitempty" description:"Glusterfs volume resource provisioned by an admin; see http://releases.k8s.io/HEAD/examples/glusterfs/README.md"`
// NFS represents an NFS mount on the host
@@ -1715,7 +1715,7 @@ type StatusCause struct {
}
// CauseType is a machine readable value providing more detail about what
-// occured in a status response. An operation may have multiple causes for a
+// occurred in a status response. An operation may have multiple causes for a
// status (whether Failure or Success).
type CauseType string
@@ -1799,8 +1799,8 @@ type Event struct {
// The time at which the event was first recorded. (Time of server receipt is in TypeMeta.)
FirstTimestamp util.Time `json:"firstTimestamp,omitempty" description:"the time at which the event was first recorded"`
- // The time at which the most recent occurance of this event was recorded.
- LastTimestamp util.Time `json:"lastTimestamp,omitempty" description:"the time at which the most recent occurance of this event was recorded"`
+ // The time at which the most recent occurrence of this event was recorded.
+ LastTimestamp util.Time `json:"lastTimestamp,omitempty" description:"the time at which the most recent occurrence of this event was recorded"`
// The number of times this event has occurred.
Count int `json:"count,omitempty" description:"the number of times this event has occurred"`
diff --git a/pkg/api/validation/validation.go b/pkg/api/validation/validation.go
index 01348ff360e..da66f051341 100644
--- a/pkg/api/validation/validation.go
+++ b/pkg/api/validation/validation.go
@@ -221,7 +221,7 @@ func ValidateObjectMeta(meta *api.ObjectMeta, requiresNamespace bool, nameFn Val
}
// If the generated name validates, but the calculated value does not, it's a problem with generation, and we
// report it here. This may confuse users, but indicates a programming bug and still must be validated.
- // If there are multiple fields out of which one is required then add a or as a seperator
+ // If there are multiple fields out of which one is required then add a or as a separator
if len(meta.Name) == 0 {
allErrs = append(allErrs, errs.NewFieldRequired("name or generateName"))
} else {
diff --git a/pkg/auth/authorizer/abac/abac_test.go b/pkg/auth/authorizer/abac/abac_test.go
index 42f8b936f1c..2cd0685b6c5 100644
--- a/pkg/auth/authorizer/abac/abac_test.go
+++ b/pkg/auth/authorizer/abac/abac_test.go
@@ -110,7 +110,7 @@ func NotTestAuthorize(t *testing.T) {
{User: uChuck, RO: true, Resource: "pods", NS: "ns1", ExpectAllow: false},
{User: uChuck, RO: true, Resource: "floop", NS: "ns1", ExpectAllow: false},
// Chunk can't access things with no kind or namespace
- // TODO: find a way to give someone access to miscelaneous endpoints, such as
+ // TODO: find a way to give someone access to miscellaneous endpoints, such as
// /healthz, /version, etc.
{User: uChuck, RO: true, Resource: "", NS: "", ExpectAllow: false},
}
diff --git a/pkg/auth/authorizer/interfaces.go b/pkg/auth/authorizer/interfaces.go
index b44f4d9e71d..b93da19ab14 100644
--- a/pkg/auth/authorizer/interfaces.go
+++ b/pkg/auth/authorizer/interfaces.go
@@ -24,7 +24,7 @@ import (
// that is used to make an authorization decision.
type Attributes interface {
// The user string which the request was authenticated as, or empty if
- // no authentication occured and the request was allowed to proceed.
+ // no authentication occurred and the request was allowed to proceed.
GetUserName() string
// The list of group names the authenticated user is a member of. Can be
diff --git a/pkg/client/cache/delta_fifo.go b/pkg/client/cache/delta_fifo.go
index 2ed7f385b00..96315b8d590 100644
--- a/pkg/client/cache/delta_fifo.go
+++ b/pkg/client/cache/delta_fifo.go
@@ -277,7 +277,7 @@ func (f *DeltaFIFO) GetByKey(key string) (item interface{}, exists bool, err err
// Pop blocks until an item is added to the queue, and then returns it. If
// multiple items are ready, they are returned in the order in which they were
// added/updated. The item is removed from the queue (and the store) before it
-// is returned, so if you don't succesfully process it, you need to add it back
+// is returned, so if you don't successfully process it, you need to add it back
// with AddIfNotPresent().
//
// Pop returns a 'Deltas', which has a complete list of all the things
diff --git a/pkg/client/cache/expiration_cache_test.go b/pkg/client/cache/expiration_cache_test.go
index 5c6b87e8e97..352243cc316 100644
--- a/pkg/client/cache/expiration_cache_test.go
+++ b/pkg/client/cache/expiration_cache_test.go
@@ -118,7 +118,7 @@ func TestTTLPolicy(t *testing.T) {
}
fakeTimestampedEntry.timestamp = fakeTime
if policy.IsExpired(fakeTimestampedEntry) {
- t.Errorf("TTL Cache should not expire entires before ttl")
+ t.Errorf("TTL Cache should not expire entries before ttl")
}
fakeTimestampedEntry.timestamp = expiredTime
if !policy.IsExpired(fakeTimestampedEntry) {
diff --git a/pkg/client/cache/fifo.go b/pkg/client/cache/fifo.go
index 89fe4c9b65c..45e5f669411 100644
--- a/pkg/client/cache/fifo.go
+++ b/pkg/client/cache/fifo.go
@@ -163,7 +163,7 @@ func (f *FIFO) GetByKey(key string) (item interface{}, exists bool, err error) {
// Pop waits until an item is ready and returns it. If multiple items are
// ready, they are returned in the order in which they were added/updated.
// The item is removed from the queue (and the store) before it is returned,
-// so if you don't succesfully process it, you need to add it back with
+// so if you don't successfully process it, you need to add it back with
// AddIfNotPresent().
func (f *FIFO) Pop() interface{} {
f.lock.Lock()
diff --git a/pkg/client/cache/poller.go b/pkg/client/cache/poller.go
index 0af3a75d49b..f7a3f864ffb 100644
--- a/pkg/client/cache/poller.go
+++ b/pkg/client/cache/poller.go
@@ -30,7 +30,7 @@ type Enumerator interface {
Get(index int) (object interface{})
}
-// GetFunc should return an enumerator that you wish the Poller to proccess.
+// GetFunc should return an enumerator that you wish the Poller to process.
type GetFunc func() (Enumerator, error)
// Poller is like Reflector, but it periodically polls instead of watching.
diff --git a/pkg/client/chaosclient/chaosclient.go b/pkg/client/chaosclient/chaosclient.go
index 2f49e062a15..ec50ce2f625 100644
--- a/pkg/client/chaosclient/chaosclient.go
+++ b/pkg/client/chaosclient/chaosclient.go
@@ -103,7 +103,7 @@ type pIntercept struct {
p float64
}
-// P returns a ChaosFunc that fires with a probabilty of p (p between 0.0
+// P returns a ChaosFunc that fires with a probability of p (p between 0.0
// and 1.0 with 0.0 meaning never and 1.0 meaning always).
func (s Seed) P(p float64, c Chaos) Chaos {
return pIntercept{c, s, p}
diff --git a/pkg/client/flags.go b/pkg/client/flags.go
index f05fcd831c9..644ce0ab6d8 100644
--- a/pkg/client/flags.go
+++ b/pkg/client/flags.go
@@ -32,7 +32,7 @@ type FlagSet interface {
}
// BindClientConfigFlags registers a standard set of CLI flags for connecting to a Kubernetes API server.
-// TODO this method is superceded by pkg/client/clientcmd/client_builder.go
+// TODO this method is superseded by pkg/client/clientcmd/client_builder.go
func BindClientConfigFlags(flags FlagSet, config *Config) {
flags.StringVar(&config.Host, "master", config.Host, "The address of the Kubernetes API server")
flags.StringVar(&config.Version, "api_version", config.Version, "The API version to use when talking to the server")
diff --git a/pkg/client/record/event.go b/pkg/client/record/event.go
index bc7071eb641..a4ebfaf76ac 100644
--- a/pkg/client/record/event.go
+++ b/pkg/client/record/event.go
@@ -68,16 +68,16 @@ type EventRecorder interface {
// EventBroadcaster knows how to receive events and send them to any EventSink, watcher, or log.
type EventBroadcaster interface {
- // StartEventWatcher starts sending events recieved from this EventBroadcaster to the given
+ // StartEventWatcher starts sending events received from this EventBroadcaster to the given
// event handler function. The return value can be ignored or used to stop recording, if
// desired.
StartEventWatcher(eventHandler func(*api.Event)) watch.Interface
- // StartRecordingToSink starts sending events recieved from this EventBroadcaster to the given
+ // StartRecordingToSink starts sending events received from this EventBroadcaster to the given
// sink. The return value can be ignored or used to stop recording, if desired.
StartRecordingToSink(sink EventSink) watch.Interface
- // StartLogging starts sending events recieved from this EventBroadcaster to the given logging
+ // StartLogging starts sending events received from this EventBroadcaster to the given logging
// function. The return value can be ignored or used to stop recording, if desired.
StartLogging(logf func(format string, args ...interface{})) watch.Interface
@@ -95,7 +95,7 @@ type eventBroadcasterImpl struct {
*watch.Broadcaster
}
-// StartRecordingToSink starts sending events recieved from the specified eventBroadcaster to the given sink.
+// StartRecordingToSink starts sending events received from the specified eventBroadcaster to the given sink.
// The return value can be ignored or used to stop recording, if desired.
// TODO: make me an object with parameterizable queue length and retry interval
func (eventBroadcaster *eventBroadcasterImpl) StartRecordingToSink(sink EventSink) watch.Interface {
@@ -195,7 +195,7 @@ func recordEvent(sink EventSink, event *api.Event, updateExistingEvent bool) boo
return false
}
-// StartLogging starts sending events recieved from this EventBroadcaster to the given logging function.
+// StartLogging starts sending events received from this EventBroadcaster to the given logging function.
// The return value can be ignored or used to stop recording, if desired.
func (eventBroadcaster *eventBroadcasterImpl) StartLogging(logf func(format string, args ...interface{})) watch.Interface {
return eventBroadcaster.StartEventWatcher(
@@ -204,7 +204,7 @@ func (eventBroadcaster *eventBroadcasterImpl) StartLogging(logf func(format stri
})
}
-// StartEventWatcher starts sending events recieved from this EventBroadcaster to the given event handler function.
+// StartEventWatcher starts sending events received from this EventBroadcaster to the given event handler function.
// The return value can be ignored or used to stop recording, if desired.
func (eventBroadcaster *eventBroadcasterImpl) StartEventWatcher(eventHandler func(*api.Event)) watch.Interface {
watcher := eventBroadcaster.Watch()
diff --git a/pkg/client/record/event_test.go b/pkg/client/record/event_test.go
index 13054f2ffc6..0885ef9e7b5 100644
--- a/pkg/client/record/event_test.go
+++ b/pkg/client/record/event_test.go
@@ -318,7 +318,7 @@ func validateEvent(actualEvent *api.Event, expectedEvent *api.Event, t *testing.
}
if actualEvent.FirstTimestamp.Equal(actualEvent.LastTimestamp) {
if expectCompression {
- t.Errorf("FirstTimestamp (%q) and LastTimestamp (%q) must be equal to indicate only one occurance of the event, but were different. Actual Event: %#v", actualEvent.FirstTimestamp, actualEvent.LastTimestamp, *actualEvent)
+ t.Errorf("FirstTimestamp (%q) and LastTimestamp (%q) must be equal to indicate only one occurrence of the event, but were different. Actual Event: %#v", actualEvent.FirstTimestamp, actualEvent.LastTimestamp, *actualEvent)
}
} else {
if !expectCompression {
diff --git a/pkg/client/record/events_cache.go b/pkg/client/record/events_cache.go
index a544780ef44..67ca127745b 100644
--- a/pkg/client/record/events_cache.go
+++ b/pkg/client/record/events_cache.go
@@ -25,13 +25,13 @@ import (
)
type history struct {
- // The number of times the event has occured since first occurance.
+ // The number of times the event has occurred since first occurrence.
Count int
// The time at which the event was first recorded.
FirstTimestamp util.Time
- // The unique name of the first occurance of this event
+ // The unique name of the first occurrence of this event
Name string
// Resource version returned from previous interaction with server
diff --git a/pkg/client/request.go b/pkg/client/request.go
index d195917d90a..fabd31065b7 100644
--- a/pkg/client/request.go
+++ b/pkg/client/request.go
@@ -641,7 +641,7 @@ func (r *Request) Upgrade(config *Config, newRoundTripperFunc func(*tls.Config)
// request connects to the server and invokes the provided function when a server response is
// received. It handles retry behavior and up front validation of requests. It wil invoke
-// fn at most once. It will return an error if a problem occured prior to connecting to the
+// fn at most once. It will return an error if a problem occurred prior to connecting to the
// server - the provided function is responsible for handling server errors.
func (r *Request) request(fn func(*http.Request, *http.Response)) error {
if r.err != nil {
diff --git a/pkg/cloudprovider/mesos/client_test.go b/pkg/cloudprovider/mesos/client_test.go
index eaf5d706b62..63b949e327c 100644
--- a/pkg/cloudprovider/mesos/client_test.go
+++ b/pkg/cloudprovider/mesos/client_test.go
@@ -164,7 +164,7 @@ func (md FakeMasterDetector) Done() <-chan struct{} {
return md.done
}
-// Auxilliary functions
+// Auxiliary functions
func makeHttpMocks() (*httptest.Server, *http.Client, *http.Transport) {
httpServer := httptest.NewServer(http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
diff --git a/pkg/controller/node/nodecontroller_test.go b/pkg/controller/node/nodecontroller_test.go
index d10b96b49a0..adf8d367ed4 100644
--- a/pkg/controller/node/nodecontroller_test.go
+++ b/pkg/controller/node/nodecontroller_test.go
@@ -44,7 +44,7 @@ const (
// FakeNodeHandler is a fake implementation of NodesInterface and NodeInterface. It
// allows test cases to have fine-grained control over mock behaviors. We also need
// PodsInterface and PodInterface to test list & delet pods, which is implemented in
-// the embeded client.Fake field.
+// the embedded client.Fake field.
type FakeNodeHandler struct {
*testclient.Fake
diff --git a/pkg/controller/node/podevictor_test.go b/pkg/controller/node/podevictor_test.go
index b7ae8ea3e85..dd9532efff7 100644
--- a/pkg/controller/node/podevictor_test.go
+++ b/pkg/controller/node/podevictor_test.go
@@ -43,7 +43,7 @@ func TestAddNode(t *testing.T) {
queuePattern := []string{"first", "second", "third"}
if len(evictor.queue.queue) != len(queuePattern) {
- t.Fatalf("Queue %v should have lenght %d", evictor.queue.queue, len(queuePattern))
+ t.Fatalf("Queue %v should have length %d", evictor.queue.queue, len(queuePattern))
}
if !CheckQueueEq(queuePattern, evictor.queue.queue) {
t.Errorf("Invalid queue. Got %v, expected %v", evictor.queue.queue, queuePattern)
@@ -89,7 +89,7 @@ func TestDelNode(t *testing.T) {
queuePattern = []string{"first", "third"}
if len(evictor.queue.queue) != len(queuePattern) {
- t.Fatalf("Queue %v should have lenght %d", evictor.queue.queue, len(queuePattern))
+ t.Fatalf("Queue %v should have length %d", evictor.queue.queue, len(queuePattern))
}
if !CheckQueueEq(queuePattern, evictor.queue.queue) {
t.Errorf("Invalid queue. Got %v, expected %v", evictor.queue.queue, queuePattern)
@@ -111,7 +111,7 @@ func TestDelNode(t *testing.T) {
queuePattern = []string{"first", "second"}
if len(evictor.queue.queue) != len(queuePattern) {
- t.Fatalf("Queue %v should have lenght %d", evictor.queue.queue, len(queuePattern))
+ t.Fatalf("Queue %v should have length %d", evictor.queue.queue, len(queuePattern))
}
if !CheckQueueEq(queuePattern, evictor.queue.queue) {
t.Errorf("Invalid queue. Got %v, expected %v", evictor.queue.queue, queuePattern)
diff --git a/pkg/controller/replication/replication_controller.go b/pkg/controller/replication/replication_controller.go
index 412b1750b85..5637371a28d 100644
--- a/pkg/controller/replication/replication_controller.go
+++ b/pkg/controller/replication/replication_controller.go
@@ -139,7 +139,7 @@ func NewReplicationManager(kubeClient client.Interface, burstReplicas int) *Repl
}
rm.enqueueController(cur)
},
- // This will enter the sync loop and no-op, becuase the controller has been deleted from the store.
+ // This will enter the sync loop and no-op, because the controller has been deleted from the store.
// Note that deleting a controller immediately after scaling it to 0 will not work. The recommended
// way of achieving this is by performing a `stop` operation on the controller.
DeleteFunc: rm.enqueueController,
diff --git a/pkg/controller/replication/replication_controller_test.go b/pkg/controller/replication/replication_controller_test.go
index 5a27aac8b63..589c8dd9941 100644
--- a/pkg/controller/replication/replication_controller_test.go
+++ b/pkg/controller/replication/replication_controller_test.go
@@ -46,10 +46,10 @@ type FakePodControl struct {
err error
}
-// Give each test that starts a background controller upto 1/2 a second.
+// Give each test that starts a background controller up to 1/2 a second.
// Since we need to start up a goroutine to test watch, this routine needs
// to get cpu before the test can complete. If the test is starved of cpu,
-// the watch test will take upto 1/2 a second before timing out.
+// the watch test will take up to 1/2 a second before timing out.
const controllerTimeout = 500 * time.Millisecond
var alwaysReady = func() bool { return true }
@@ -638,7 +638,7 @@ func TestUpdatePods(t *testing.T) {
}
func TestControllerUpdateRequeue(t *testing.T) {
- // This server should force a requeue of the controller becuase it fails to update status.Replicas.
+ // This server should force a requeue of the controller because it fails to update status.Replicas.
fakeHandler := util.FakeHandler{
StatusCode: 500,
ResponseBody: "",
@@ -806,7 +806,7 @@ func doTestControllerBurstReplicas(t *testing.T, burstReplicas, numReplicas int)
// Create/Delete the last pod
// The last add pod will decrease the expectation of the rc to 0,
- // which will cause it to create/delete the remaining replicas upto burstReplicas.
+ // which will cause it to create/delete the remaining replicas up to burstReplicas.
if replicas != 0 {
manager.podStore.Store.Add(&pods.Items[expectedPods-1])
manager.addPod(&pods.Items[expectedPods-1])
diff --git a/pkg/controller/service/servicecontroller.go b/pkg/controller/service/servicecontroller.go
index 80258ac14e3..69c5423e875 100644
--- a/pkg/controller/service/servicecontroller.go
+++ b/pkg/controller/service/servicecontroller.go
@@ -242,7 +242,7 @@ func (s *ServiceController) processDelta(delta *cache.Delta) (error, bool) {
return err, retry
}
// Always update the cache upon success.
- // NOTE: Since we update the cached service if and only if we successully
+ // NOTE: Since we update the cached service if and only if we successfully
// processed it, a cached service being nil implies that it hasn't yet
// been successfully processed.
cachedService.appliedState = service
diff --git a/pkg/conversion/converter.go b/pkg/conversion/converter.go
index 9bb9b041743..fcbea30cec7 100644
--- a/pkg/conversion/converter.go
+++ b/pkg/conversion/converter.go
@@ -111,7 +111,7 @@ type Scope interface {
DefaultConvert(src, dest interface{}, flags FieldMatchingFlags) error
// If registered, returns a function applying defaults for objects of a given type.
- // Used for automatically generating convertion functions.
+ // Used for automatically generating conversion functions.
DefaultingInterface(inType reflect.Type) (interface{}, bool)
// SrcTags and DestTags contain the struct tags that src and dest had, respectively.
@@ -649,7 +649,7 @@ type kvValue interface {
tagOf(key string) reflect.StructTag
// Will return the zero Value if the key doesn't exist.
value(key string) reflect.Value
- // Maps require explict setting-- will do nothing for structs.
+ // Maps require explicit setting-- will do nothing for structs.
// Returns false on failure.
confirmSet(key string, v reflect.Value) bool
}
diff --git a/pkg/httplog/log.go b/pkg/httplog/log.go
index 1c28716d920..77b2dbe8e77 100644
--- a/pkg/httplog/log.go
+++ b/pkg/httplog/log.go
@@ -83,7 +83,7 @@ func DefaultStacktracePred(status int) bool {
//
// defer NewLogged(req, &w).StacktraceWhen(StatusIsNot(200, 202)).Log()
//
-// (Only the call to Log() is defered, so you can set everything up in one line!)
+// (Only the call to Log() is deferred, so you can set everything up in one line!)
//
// Note that this *changes* your writer, to route response writing actions
// through the logger.
diff --git a/pkg/kubectl/cmd/cmd_test.go b/pkg/kubectl/cmd/cmd_test.go
index 005e3bb8ad8..0dfe45afb86 100644
--- a/pkg/kubectl/cmd/cmd_test.go
+++ b/pkg/kubectl/cmd/cmd_test.go
@@ -399,7 +399,7 @@ func ExamplePrintServiceWithNamespacesAndLabels() {
// ||
}
-func TestNormalizationFuncGlobalExistance(t *testing.T) {
+func TestNormalizationFuncGlobalExistence(t *testing.T) {
// This test can be safely deleted when we will not support multiple flag formats
root := NewKubectlCommand(cmdutil.NewFactory(nil), os.Stdin, os.Stdout, os.Stderr)
diff --git a/pkg/kubectl/cmd/config/config_test.go b/pkg/kubectl/cmd/config/config_test.go
index 18d701b9aed..44eeef37826 100644
--- a/pkg/kubectl/cmd/config/config_test.go
+++ b/pkg/kubectl/cmd/config/config_test.go
@@ -95,13 +95,13 @@ func TestSetCurrentContext(t *testing.T) {
test.run(t)
}
-func TestSetNonExistantContext(t *testing.T) {
+func TestSetNonExistentContext(t *testing.T) {
expectedConfig := newRedFederalCowHammerConfig()
test := configCommandTest{
- args: []string{"use-context", "non-existant-config"},
+ args: []string{"use-context", "non-existent-config"},
startingConfig: expectedConfig,
expectedConfig: expectedConfig,
- expectedOutputs: []string{`No context exists with the name: "non-existant-config"`},
+ expectedOutputs: []string{`No context exists with the name: "non-existent-config"`},
}
test.run(t)
}
diff --git a/pkg/kubectl/cmd/namespace.go b/pkg/kubectl/cmd/namespace.go
index cd3a12d4d5b..e50e4c0785e 100644
--- a/pkg/kubectl/cmd/namespace.go
+++ b/pkg/kubectl/cmd/namespace.go
@@ -28,13 +28,13 @@ import (
func NewCmdNamespace(out io.Writer) *cobra.Command {
cmd := &cobra.Command{
Use: "namespace [namespace]",
- Short: "SUPERCEDED: Set and view the current Kubernetes namespace",
- Long: `SUPERCEDED: Set and view the current Kubernetes namespace scope for command line requests.
+ Short: "SUPERSEDED: Set and view the current Kubernetes namespace",
+ Long: `SUPERSEDED: Set and view the current Kubernetes namespace scope for command line requests.
-namespace has been superceded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details.
+namespace has been superseded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details.
`,
Run: func(cmd *cobra.Command, args []string) {
- util.CheckErr(fmt.Errorf("namespace has been superceded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details."))
+ util.CheckErr(fmt.Errorf("namespace has been superseded by the context.namespace field of .kubeconfig files. See 'kubectl config set-context --help' for more details."))
},
}
return cmd
diff --git a/pkg/kubectl/cmd/util/factory.go b/pkg/kubectl/cmd/util/factory.go
index cc4e3380ba6..ae024167acc 100644
--- a/pkg/kubectl/cmd/util/factory.go
+++ b/pkg/kubectl/cmd/util/factory.go
@@ -248,7 +248,7 @@ func (f *Factory) BindFlags(flags *pflag.FlagSet) {
// to do that automatically for every subcommand.
flags.BoolVar(&f.clients.matchVersion, FlagMatchBinaryVersion, false, "Require server version to match client version")
- // Normalize all flags that are comming from other packages or pre-configurations
+ // Normalize all flags that are coming from other packages or pre-configurations
// a.k.a. change all "_" to "-". e.g. glog package
flags.SetNormalizeFunc(util.WordSepNormalizeFunc)
}
diff --git a/pkg/kubectl/resource_printer.go b/pkg/kubectl/resource_printer.go
index 0421a872f78..83903bf789e 100644
--- a/pkg/kubectl/resource_printer.go
+++ b/pkg/kubectl/resource_printer.go
@@ -176,7 +176,7 @@ type handlerEntry struct {
// HumanReadablePrinter is an implementation of ResourcePrinter which attempts to provide
// more elegant output. It is not threadsafe, but you may call PrintObj repeatedly; headers
// will only be printed if the object type changes. This makes it useful for printing items
-// recieved from watches.
+// received from watches.
type HumanReadablePrinter struct {
handlerMap map[reflect.Type]*handlerEntry
noHeaders bool
diff --git a/pkg/kubelet/config/config_test.go b/pkg/kubelet/config/config_test.go
index 7c71d6aea8d..44335165fd7 100644
--- a/pkg/kubelet/config/config_test.go
+++ b/pkg/kubelet/config/config_test.go
@@ -91,7 +91,7 @@ func expectPodUpdate(t *testing.T, ch <-chan kubelet.PodUpdate, expected ...kube
for i := range expected {
update := <-ch
sort.Sort(sortedPods(update.Pods))
- // Clear the annotation field before the comparision.
+ // Clear the annotation field before the comparison.
// TODO: consider mock out recordFirstSeen in config.go
for _, pod := range update.Pods {
delete(pod.Annotations, kubelet.ConfigFirstSeenAnnotationKey)
diff --git a/pkg/kubelet/dockertools/instrumented_docker.go b/pkg/kubelet/dockertools/instrumented_docker.go
index 62f3418b8f0..7fd7930d069 100644
--- a/pkg/kubelet/dockertools/instrumented_docker.go
+++ b/pkg/kubelet/dockertools/instrumented_docker.go
@@ -39,7 +39,7 @@ func recordOperation(operation string, start time.Time) {
metrics.DockerOperationsLatency.WithLabelValues(operation).Observe(metrics.SinceInMicroseconds(start))
}
-// Record error for metric if an error occured.
+// Record error for metric if an error occurred.
func recordError(operation string, err error) {
if err != nil {
metrics.DockerErrors.WithLabelValues(operation).Inc()
diff --git a/pkg/kubelet/dockertools/manager.go b/pkg/kubelet/dockertools/manager.go
index 93521592a00..f613b62a49d 100644
--- a/pkg/kubelet/dockertools/manager.go
+++ b/pkg/kubelet/dockertools/manager.go
@@ -1298,7 +1298,7 @@ func (dm *DockerManager) runContainerInPod(pod *api.Pod, container *api.Containe
}
// currently, Docker does not have a flag by which the ndots option can be passed.
- // (A seperate issue has been filed with Docker to add a ndots flag)
+ // (A separate issue has been filed with Docker to add a ndots flag)
// The addNDotsOption call appends the ndots option to the resolv.conf file generated by docker.
// This resolv.conf file is shared by all containers of the same pod, and needs to be modified only once per pod.
// we modify it when the pause container is created since it is the first container created in the pod since it holds
diff --git a/pkg/kubelet/image_manager.go b/pkg/kubelet/image_manager.go
index 7d350f6919c..4c017cd48db 100644
--- a/pkg/kubelet/image_manager.go
+++ b/pkg/kubelet/image_manager.go
@@ -217,7 +217,7 @@ func (im *realImageManager) GarbageCollect() error {
// Tries to free bytesToFree worth of images on the disk.
//
-// Returns the number of bytes free and an error if any occured. The number of
+// Returns the number of bytes free and an error if any occurred. The number of
// bytes freed is always returned.
// Note that error may be nil and the number of bytes free may be less
// than bytesToFree.
diff --git a/pkg/kubelet/kubelet.go b/pkg/kubelet/kubelet.go
index 27dcb2343fa..6ebebf9d3c3 100644
--- a/pkg/kubelet/kubelet.go
+++ b/pkg/kubelet/kubelet.go
@@ -1701,7 +1701,7 @@ func (kl *Kubelet) handleNotFittingPods(pods []*api.Pod) []*api.Pod {
// that don't fit on the node, and may reject pods if node is overcommitted.
func (kl *Kubelet) admitPods(allPods []*api.Pod, podSyncTypes map[types.UID]SyncPodType) []*api.Pod {
// Pod phase progresses monotonically. Once a pod has reached a final state,
- // it should never leave irregardless of the restart policy. The statuses
+ // it should never leave regardless of the restart policy. The statuses
// of such pods should not be changed, and there is no need to sync them.
// TODO: the logic here does not handle two cases:
// 1. If the containers were removed immediately after they died, kubelet
diff --git a/pkg/kubelet/kubelet_test.go b/pkg/kubelet/kubelet_test.go
index 925c331335b..c92cc85a608 100644
--- a/pkg/kubelet/kubelet_test.go
+++ b/pkg/kubelet/kubelet_test.go
@@ -409,7 +409,7 @@ func TestMountExternalVolumes(t *testing.T) {
}
podVolumes, err := kubelet.mountExternalVolumes(&pod)
if err != nil {
- t.Errorf("Expected sucess: %v", err)
+ t.Errorf("Expected success: %v", err)
}
expectedPodVolumes := []string{"vol1"}
if len(expectedPodVolumes) != len(podVolumes) {
diff --git a/pkg/kubelet/network/exec/exec.go b/pkg/kubelet/network/exec/exec.go
index a723b3fa169..516e1904d92 100644
--- a/pkg/kubelet/network/exec/exec.go
+++ b/pkg/kubelet/network/exec/exec.go
@@ -22,7 +22,7 @@ limitations under the License.
// plugin-name/
// where, 'executable' has the following requirements:
// - should have exec permissions
-// - should give non-zero exit code on failure, and zero on sucess
+// - should give non-zero exit code on failure, and zero on success
// - the arguments will be
// whereupon, will be one of:
// - init, called when the kubelet loads the plugin
diff --git a/pkg/kubelet/rkt/rkt.go b/pkg/kubelet/rkt/rkt.go
index 23da6c5402b..4ca198538c2 100644
--- a/pkg/kubelet/rkt/rkt.go
+++ b/pkg/kubelet/rkt/rkt.go
@@ -636,7 +636,7 @@ func (r *runtime) makeRuntimePod(unitName string, podInfos map[string]*podInfo)
}
// GetPods runs 'systemctl list-unit' and 'rkt list' to get the list of rkt pods.
-// Then it will use the result to contruct a list of container runtime pods.
+// Then it will use the result to construct a list of container runtime pods.
// If all is false, then only running pods will be returned, otherwise all pods will be
// returned.
func (r *runtime) GetPods(all bool) ([]*kubecontainer.Pod, error) {
diff --git a/pkg/kubelet/server.go b/pkg/kubelet/server.go
index 88c526bcb04..ed65e5c10a7 100644
--- a/pkg/kubelet/server.go
+++ b/pkg/kubelet/server.go
@@ -686,11 +686,11 @@ type StatsRequest struct {
NumStats int `json:"num_stats,omitempty"`
// Start time for which to query information.
- // If ommitted, the beginning of time is assumed.
+ // If omitted, the beginning of time is assumed.
Start time.Time `json:"start,omitempty"`
// End time for which to query information.
- // If ommitted, current time is assumed.
+ // If omitted, current time is assumed.
End time.Time `json:"end,omitempty"`
// Whether to also include information from subcontainers.
diff --git a/pkg/master/master.go b/pkg/master/master.go
index 85bb7cdf8ef..12de1145808 100644
--- a/pkg/master/master.go
+++ b/pkg/master/master.go
@@ -313,7 +313,7 @@ func setDefaults(c *Config) {
// Public fields:
// Handler -- The returned master has a field TopHandler which is an
// http.Handler which handles all the endpoints provided by the master,
-// including the API, the UI, and miscelaneous debugging endpoints. All
+// including the API, the UI, and miscellaneous debugging endpoints. All
// these are subject to authorization and authentication.
// InsecureHandler -- an http.Handler which handles all the same
// endpoints as Handler, but no authorization and authentication is done.
diff --git a/pkg/proxy/userspace/proxier.go b/pkg/proxy/userspace/proxier.go
index 4b3ab339a62..a505564d15e 100644
--- a/pkg/proxy/userspace/proxier.go
+++ b/pkg/proxy/userspace/proxier.go
@@ -244,7 +244,7 @@ func (proxier *Proxier) addServiceOnPort(service proxy.ServicePortName, protocol
socket: sock,
timeout: timeout,
sessionAffinityType: api.ServiceAffinityNone, // default
- stickyMaxAgeMinutes: 180, // TODO: paramaterize this in the API.
+ stickyMaxAgeMinutes: 180, // TODO: parameterize this in the API.
}
proxier.setServiceInfo(service, si)
diff --git a/pkg/registry/generic/etcd/etcd.go b/pkg/registry/generic/etcd/etcd.go
index ed7787e421a..9275f78a49e 100644
--- a/pkg/registry/generic/etcd/etcd.go
+++ b/pkg/registry/generic/etcd/etcd.go
@@ -490,7 +490,7 @@ func (e *Etcd) WatchPredicate(ctx api.Context, m generic.Matcher, resourceVersio
// if the TTL cannot be calculated. The defaultTTL is changed to 1 if less than zero. Zero means
// no TTL, not expire immediately.
func (e *Etcd) calculateTTL(obj runtime.Object, defaultTTL int64, update bool) (ttl uint64, err error) {
- // etcd may return a negative TTL for a node if the expiration has not occured due
+ // etcd may return a negative TTL for a node if the expiration has not occurred due
// to server lag - we will ensure that the value is at least set.
if defaultTTL < 0 {
defaultTTL = 1
diff --git a/pkg/registry/service/registry.go b/pkg/registry/service/registry.go
index b918605bf1a..baab7d1ec52 100644
--- a/pkg/registry/service/registry.go
+++ b/pkg/registry/service/registry.go
@@ -40,6 +40,6 @@ type RangeRegistry interface {
// or an error if the allocation could not be retrieved.
Get() (*api.RangeAllocation, error)
// CreateOrUpdate should create or update the provide allocation, unless a conflict
- // has occured since the item was last created.
+ // has occurred since the item was last created.
CreateOrUpdate(*api.RangeAllocation) error
}
diff --git a/pkg/runtime/interfaces.go b/pkg/runtime/interfaces.go
index 3cea83f80dc..bb9946ed247 100644
--- a/pkg/runtime/interfaces.go
+++ b/pkg/runtime/interfaces.go
@@ -129,7 +129,7 @@ type SelfLinker interface {
}
// All api types must support the Object interface. It's deliberately tiny so that this is not an onerous
-// burden. Implement it with a pointer reciever; this will allow us to use the go compiler to check the
+// burden. Implement it with a pointer receiver; this will allow us to use the go compiler to check the
// one thing about our objects that it's capable of checking for us.
type Object interface {
// This function is used only to enforce membership. It's never called.
diff --git a/pkg/runtime/scheme.go b/pkg/runtime/scheme.go
index a5620794c75..a90f1d43248 100644
--- a/pkg/runtime/scheme.go
+++ b/pkg/runtime/scheme.go
@@ -83,7 +83,7 @@ func (self *Scheme) embeddedObjectToRawExtension(in *EmbeddedObject, out *RawExt
return err
}
- // Copy the kind field into the ouput object.
+ // Copy the kind field into the output object.
err = s.Convert(
&emptyPlugin{PluginBase: PluginBase{Kind: kind}},
outObj,
diff --git a/pkg/storage/etcd/etcd_helper.go b/pkg/storage/etcd/etcd_helper.go
index 54e32e23fab..5688b9f0fe4 100644
--- a/pkg/storage/etcd/etcd_helper.go
+++ b/pkg/storage/etcd/etcd_helper.go
@@ -476,7 +476,7 @@ func (h *etcdHelper) getFromCache(index uint64) (runtime.Object, bool) {
}()
obj, found := h.cache.Get(index)
if found {
- // We should not return the object itself to avoid poluting the cache if someone
+ // We should not return the object itself to avoid polluting the cache if someone
// modifies returned values.
objCopy, err := h.copier.Copy(obj.(runtime.Object))
if err != nil {
diff --git a/pkg/storage/etcd/etcd_util.go b/pkg/storage/etcd/etcd_util.go
index cf5543c4ded..ec56577e9f5 100644
--- a/pkg/storage/etcd/etcd_util.go
+++ b/pkg/storage/etcd/etcd_util.go
@@ -34,7 +34,7 @@ func IsEtcdNotFound(err error) bool {
return isEtcdErrorNum(err, tools.EtcdErrorCodeNotFound)
}
-// IsEtcdNodeExist returns true iff err is an etcd node aleady exist error.
+// IsEtcdNodeExist returns true iff err is an etcd node already exist error.
func IsEtcdNodeExist(err error) bool {
return isEtcdErrorNum(err, tools.EtcdErrorCodeNodeExist)
}
diff --git a/pkg/storage/interfaces.go b/pkg/storage/interfaces.go
index ccdff1ae4bb..0a043573760 100644
--- a/pkg/storage/interfaces.go
+++ b/pkg/storage/interfaces.go
@@ -124,10 +124,10 @@ type Interface interface {
// GuaranteedUpdate keeps calling 'tryUpdate()' to update key 'key' (of type 'ptrToType')
// retrying the update until success if there is index conflict.
// Note that object passed to tryUpdate may change acress incovations of tryUpdate() if
- // other writers are simultanously updateing it, to tryUpdate() needs to take into account
+ // other writers are simultaneously updateing it, to tryUpdate() needs to take into account
// the current contents of the object when deciding how the update object should look.
//
- // Exmaple:
+ // Example:
//
// s := /* implementation of Interface */
// err := s.GuaranteedUpdate(
diff --git a/pkg/ui/data/swagger/datafile.go b/pkg/ui/data/swagger/datafile.go
index f18d36d65fa..558ac113c12 100644
--- a/pkg/ui/data/swagger/datafile.go
+++ b/pkg/ui/data/swagger/datafile.go
@@ -7987,7 +7987,7 @@ function marked(src, opt, callback) {
} catch (e) {
e.message += '\nPlease report this to https://github.com/chjj/marked.';
if ((opt || marked.defaults).silent) {
- return 'An error occured:
'
+ return 'An error occurred:
'
+ escape(e.message + '', true)
+ '
';
}
@@ -8641,7 +8641,7 @@ var Shred = function(options) {
this.logCurl = options.logCurl || false;
};
-// Most of the real work is done in the request and reponse classes.
+// Most of the real work is done in the request and response classes.
Shred.Request = require("./shred/request");
Shred.Response = require("./shred/response");
@@ -9840,7 +9840,7 @@ Changelog:
a regress. I appologize for that.
2010.05.09 - 0.5:
- - bug fix: 0 is now preceeded with a + sign
+ - bug fix: 0 is now preceded with a + sign
- bug fix: the sign was not at the right position on padded results (Kamal Abdali)
- switched from GPL to BSD license
@@ -46921,7 +46921,7 @@ window.SwaggerUi.Views = {};
});
} else if (typeof exports === 'object') {
// Node. Does not work with strict CommonJS, but
- // only CommonJS-like enviroments that support module.exports,
+ // only CommonJS-like environments that support module.exports,
// like Node.
module.exports = factory(require('b'));
} else {
diff --git a/pkg/util/fielderrors/fielderrors.go b/pkg/util/fielderrors/fielderrors.go
index 66383443af4..fdf8fe89d01 100644
--- a/pkg/util/fielderrors/fielderrors.go
+++ b/pkg/util/fielderrors/fielderrors.go
@@ -148,7 +148,7 @@ func NewFieldTooLong(field string, value interface{}, maxLength int) *Validation
type ValidationErrorList []error
// Prefix adds a prefix to the Field of every ValidationError in the list.
-// Also adds prefixes to multiple fields if you send an or seperator.
+// Also adds prefixes to multiple fields if you send an or separator.
// Returns the list for convenience.
func (list ValidationErrorList) Prefix(prefix string) ValidationErrorList {
for i := range list {
diff --git a/pkg/util/jsonpath/parser.go b/pkg/util/jsonpath/parser.go
index e80034c5872..89438b2046c 100644
--- a/pkg/util/jsonpath/parser.go
+++ b/pkg/util/jsonpath/parser.go
@@ -166,7 +166,7 @@ func (p *Parser) parseInsideAction(cur *ListNode) error {
p.backup()
return p.parseIdentifier(cur)
default:
- return fmt.Errorf("unrecognized charactor in action: %#U", r)
+ return fmt.Errorf("unrecognized character in action: %#U", r)
}
return p.parseInsideAction(cur)
}
diff --git a/pkg/util/jsonpath/parser_test.go b/pkg/util/jsonpath/parser_test.go
index 29083dd6c44..e0102062e8b 100644
--- a/pkg/util/jsonpath/parser_test.go
+++ b/pkg/util/jsonpath/parser_test.go
@@ -107,7 +107,7 @@ type failParserTest struct {
func TestFailParser(t *testing.T) {
failParserTests := []failParserTest{
{"unclosed action", "{.hello", "unclosed action"},
- {"unrecognized charactor", "{*}", "unrecognized charactor in action: U+002A '*'"},
+ {"unrecognized character", "{*}", "unrecognized character in action: U+002A '*'"},
{"invalid number", "{+12.3.0}", "cannot parse number +12.3.0"},
{"unterminated array", "{[1}", "unterminated array"},
{"invalid index", "{[::-1]}", "invalid array index ::-1"},
diff --git a/pkg/util/proxy/transport.go b/pkg/util/proxy/transport.go
index d0a19be482f..b4f5b6b49d2 100644
--- a/pkg/util/proxy/transport.go
+++ b/pkg/util/proxy/transport.go
@@ -179,7 +179,7 @@ func rewriteHTML(reader io.Reader, writer io.Writer, urlRewriter func(string) st
return nil
}
-// rewriteResponse modifies an HTML response by updating absolute links refering
+// rewriteResponse modifies an HTML response by updating absolute links referring
// to the original host to instead refer to the proxy transport.
func (t *Transport) rewriteResponse(req *http.Request, resp *http.Response) (*http.Response, error) {
origBody := resp.Body
diff --git a/pkg/version/verflag/verflag.go b/pkg/version/verflag/verflag.go
index 7e66b5fbe4e..60683214fbb 100644
--- a/pkg/version/verflag/verflag.go
+++ b/pkg/version/verflag/verflag.go
@@ -66,7 +66,7 @@ func (v *versionValue) String() string {
return fmt.Sprintf("%v", bool(*v == VersionTrue))
}
-// The type of the flag as requred by the pflag.Value interface
+// The type of the flag as required by the pflag.Value interface
func (v *versionValue) Type() string {
return "version"
}
diff --git a/pkg/volume/gce_pd/gce_util.go b/pkg/volume/gce_pd/gce_util.go
index fde1ae31b68..b52ef3a8030 100644
--- a/pkg/volume/gce_pd/gce_util.go
+++ b/pkg/volume/gce_pd/gce_util.go
@@ -158,8 +158,8 @@ func attachDiskAndVerify(b *gcePersistentDiskBuilder, sdBeforeSet util.StringSet
// Retry on error. See issue #11321
glog.Errorf("Error checking if path exists: %v", err)
} else if pathExists {
- // A device path has succesfully been created for the PD
- glog.Infof("Succesfully attached GCE PD %q.", b.pdName)
+ // A device path has successfully been created for the PD
+ glog.Infof("Successfully attached GCE PD %q.", b.pdName)
return path, nil
}
}
@@ -181,7 +181,7 @@ func detachDiskAndVerify(c *gcePersistentDiskCleaner) {
defer util.HandleCrash()
// Start operation, so that other threads can wait on this detach operation.
- // Set bufferSize to 0 so senders are blocked on send until we recieve.
+ // Set bufferSize to 0 so senders are blocked on send until we receive.
ch, err := detachCleanupManager.Start(c.pdName, 0 /* bufferSize */)
if err != nil {
glog.Errorf("Error adding %q to detachCleanupManager: %v", c.pdName, err)
@@ -244,7 +244,7 @@ func detachDiskAndVerify(c *gcePersistentDiskCleaner) {
}
if allPathsRemoved {
// All paths to the PD have been succefully removed
- glog.Infof("Succesfully detached GCE PD %q.", c.pdName)
+ glog.Infof("Successfully detached GCE PD %q.", c.pdName)
return
}
diff --git a/pkg/watch/mux.go b/pkg/watch/mux.go
index 5299f7bf976..5d1f71768de 100644
--- a/pkg/watch/mux.go
+++ b/pkg/watch/mux.go
@@ -91,7 +91,7 @@ func (m *Broadcaster) Watch() Interface {
// WatchWithPrefix adds a new watcher to the list and returns an Interface for it. It sends
// queuedEvents down the new watch before beginning to send ordinary events from Broadcaster.
-// The returned watch will have a queue length that is at least large enough to accomodate
+// The returned watch will have a queue length that is at least large enough to accommodate
// all of the items in queuedEvents.
func (m *Broadcaster) WatchWithPrefix(queuedEvents []Event) Interface {
m.lock.Lock()
@@ -151,7 +151,7 @@ func (m *Broadcaster) Shutdown() {
close(m.incoming)
}
-// loop recieves from m.incoming and distributes to all watchers.
+// loop receives from m.incoming and distributes to all watchers.
func (m *Broadcaster) loop() {
// Deliberately not catching crashes here. Yes, bring down the process if there's a
// bug in watch.Broadcaster.
diff --git a/plugin/pkg/scheduler/metrics/metrics.go b/plugin/pkg/scheduler/metrics/metrics.go
index 796e61b0616..a2db2b33230 100644
--- a/plugin/pkg/scheduler/metrics/metrics.go
+++ b/plugin/pkg/scheduler/metrics/metrics.go
@@ -30,7 +30,7 @@ var (
prometheus.SummaryOpts{
Subsystem: schedulerSubsystem,
Name: "e2e_scheduling_latency_microseconds",
- Help: "E2e scheduling latency (scheduling algorith + binding)",
+ Help: "E2e scheduling latency (scheduling algorithm + binding)",
},
)
SchedulingAlgorithmLatency = prometheus.NewSummary(
diff --git a/plugin/pkg/scheduler/modeler.go b/plugin/pkg/scheduler/modeler.go
index 511a8a839f4..aef4d94803e 100644
--- a/plugin/pkg/scheduler/modeler.go
+++ b/plugin/pkg/scheduler/modeler.go
@@ -36,7 +36,7 @@ var (
)
// ExtendedPodLister: SimpleModeler needs to be able to check for a pod's
-// existance in addition to listing the pods.
+// existence in addition to listing the pods.
type ExtendedPodLister interface {
algorithm.PodLister
Exists(pod *api.Pod) (bool, error)
diff --git a/test/e2e/e2e_test.go b/test/e2e/e2e_test.go
index 5df68566196..9b9e6ee55e5 100644
--- a/test/e2e/e2e_test.go
+++ b/test/e2e/e2e_test.go
@@ -59,7 +59,7 @@ func init() {
// Randomize specs as well as suites
config.GinkgoConfig.RandomizeAllSpecs = true
- flag.StringVar(&testContext.KubeConfig, clientcmd.RecommendedConfigPathFlag, "", "Path to kubeconfig containing embeded authinfo.")
+ flag.StringVar(&testContext.KubeConfig, clientcmd.RecommendedConfigPathFlag, "", "Path to kubeconfig containing embedded authinfo.")
flag.StringVar(&testContext.KubeContext, clientcmd.FlagContext, "", "kubeconfig context to use/override. If unset, will use value from 'current-context'")
flag.StringVar(&testContext.CertDir, "cert-dir", "", "Path to the directory containing the certs. Default is empty, which doesn't use certs.")
flag.StringVar(&testContext.Host, "host", "", "The host, or apiserver, to connect to")
diff --git a/test/e2e/es_cluster_logging.go b/test/e2e/es_cluster_logging.go
index 8b00e0ac0d3..886c12e597a 100644
--- a/test/e2e/es_cluster_logging.go
+++ b/test/e2e/es_cluster_logging.go
@@ -269,7 +269,7 @@ func ClusterLevelLoggingWithElasticsearch(f *Framework) {
}
// Ask Elasticsearch to return all the log lines that were tagged with the underscore
- // verison of the name. Ask for twice as many log lines as we expect to check for
+ // version of the name. Ask for twice as many log lines as we expect to check for
// duplication bugs.
body, err = f.Client.Get().
Namespace(api.NamespaceSystem).
diff --git a/test/e2e/host_path.go b/test/e2e/host_path.go
index a7c990db65f..8c75b237321 100644
--- a/test/e2e/host_path.go
+++ b/test/e2e/host_path.go
@@ -29,7 +29,7 @@ import (
. "github.com/onsi/gomega"
)
-//TODO : Consolodate this code with the code for emptyDir.
+//TODO : Consolidate this code with the code for emptyDir.
//This will require some smart.
var _ = Describe("hostPath", func() {
var (
diff --git a/test/e2e/kubectl.go b/test/e2e/kubectl.go
index 6a21e668b34..82708c2f1f2 100644
--- a/test/e2e/kubectl.go
+++ b/test/e2e/kubectl.go
@@ -223,7 +223,7 @@ var _ = Describe("Kubectl client", func() {
It("should check if Kubernetes master services is included in cluster-info", func() {
By("validating cluster-info")
output := runKubectl("cluster-info")
- // Can't check exact strings due to terminal controll commands (colors)
+ // Can't check exact strings due to terminal control commands (colors)
requiredItems := []string{"Kubernetes master", "is running at"}
if providerIs("gce", "gke") {
requiredItems = append(requiredItems, "KubeDNS", "Heapster")
diff --git a/test/e2e/kubelet_stats.go b/test/e2e/kubelet_stats.go
index 014265ad5d4..d522f657797 100644
--- a/test/e2e/kubelet_stats.go
+++ b/test/e2e/kubelet_stats.go
@@ -43,7 +43,7 @@ import (
)
// KubeletMetric stores metrics scraped from the kubelet server's /metric endpoint.
-// TODO: Get some more structure aroud the metrics and this type
+// TODO: Get some more structure around the metrics and this type
type KubeletMetric struct {
// eg: list, info, create
Operation string
diff --git a/test/e2e/networking.go b/test/e2e/networking.go
index 244426416aa..2bcb2551330 100644
--- a/test/e2e/networking.go
+++ b/test/e2e/networking.go
@@ -217,7 +217,7 @@ var _ = Describe("Networking", func() {
Logf("Attempt %v: service/pod still starting. (error: '%v')", i, err)
continue
}
- // Finally, we pass/fail the test based on if the container's response body, as to wether or not it was able to find peers.
+ // Finally, we pass/fail the test based on if the container's response body, as to whether or not it was able to find peers.
switch {
case string(body) == "pass":
Logf("Passed on attempt %v. Cleaning up.", i)
diff --git a/test/e2e/util.go b/test/e2e/util.go
index 3449417c70e..96ee5910355 100644
--- a/test/e2e/util.go
+++ b/test/e2e/util.go
@@ -556,7 +556,7 @@ func waitForPodSuccessInNamespace(c *client.Client, podName string, contName str
})
}
-// waitForRCPodOnNode returns the pod from the given replication controller (decribed by rcName) which is scheduled on the given node.
+// waitForRCPodOnNode returns the pod from the given replication controller (described by rcName) which is scheduled on the given node.
// In case of failure or too long waiting time, an error is returned.
func waitForRCPodOnNode(c *client.Client, ns, rcName, node string) (*api.Pod, error) {
label := labels.SelectorFromSet(labels.Set(map[string]string{"name": rcName}))
@@ -579,7 +579,7 @@ func waitForRCPodOnNode(c *client.Client, ns, rcName, node string) (*api.Pod, er
return p, err
}
-// waitForRCPodToDisappear returns nil if the pod from the given replication controller (decribed by rcName) no longer exists.
+// waitForRCPodToDisappear returns nil if the pod from the given replication controller (described by rcName) no longer exists.
// In case of failure or too long waiting time, an error is returned.
func waitForRCPodToDisappear(c *client.Client, ns, rcName, podName string) error {
label := labels.SelectorFromSet(labels.Set(map[string]string{"name": rcName}))
@@ -1007,7 +1007,7 @@ func testContainerOutputInNamespace(scenarioName string, c *client.Client, pod *
continue
}
- By(fmt.Sprintf("Succesfully fetched pod logs:%v\n", string(logs)))
+ By(fmt.Sprintf("Successfully fetched pod logs:%v\n", string(logs)))
break
}
diff --git a/www/master/components/dashboard/less/dashboard.less b/www/master/components/dashboard/less/dashboard.less
index a9eebdd3d1b..a9344dbb0a2 100755
--- a/www/master/components/dashboard/less/dashboard.less
+++ b/www/master/components/dashboard/less/dashboard.less
@@ -2,7 +2,7 @@
.body-wrapper {
padding: 25px;
}
- // analagous to float:right when used with row layout
+ // analogous to float:right when used with row layout
[flex-align-self="end"] {
-webkit-align-self: flex-end;
-ms-flex-align-self: end;