You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficcontrol.apache.org by mi...@apache.org on 2016/11/07 22:23:40 UTC

[19/26] incubator-trafficcontrol git commit: merge master

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/experimental/traffic_monitor/traffic_monitor.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/traffic_monitor.go b/traffic_monitor/experimental/traffic_monitor/traffic_monitor.go
index 2a96c9d..1b726d2 100644
--- a/traffic_monitor/experimental/traffic_monitor/traffic_monitor.go
+++ b/traffic_monitor/experimental/traffic_monitor/traffic_monitor.go
@@ -1,5 +1,25 @@
 package main
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import (
 	"bytes"
 	"flag"
@@ -12,14 +32,17 @@ import (
 	"runtime"
 	"time"
 
-	_ "github.com/Comcast/traffic_control/traffic_monitor/experimental/common/instrumentation"
-	"github.com/Comcast/traffic_control/traffic_monitor/experimental/common/log"
-	"github.com/Comcast/traffic_control/traffic_monitor/experimental/traffic_monitor/config"
-	"github.com/Comcast/traffic_control/traffic_monitor/experimental/traffic_monitor/manager"
+	_ "github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/common/instrumentation"
+	"github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/common/log"
+	"github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/config"
+	"github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/manager"
 	_ "github.com/davecheney/gmx"
 )
 
+// GitRevision is the git revision of the app. The app SHOULD always be built with this set via the `-X` flag.
 var GitRevision = "No Git Revision Specified. Please build with '-X main.GitRevision=${git rev-parse HEAD}'"
+
+// BuildTimestamp is the time the app was built. The app SHOULD always be built with this set via the `-X` flag.
 var BuildTimestamp = "No Build Timestamp Specified. Please build with '-X main.BuildTimestamp=`date +'%Y-%M-%dT%H:%M:%S'`"
 
 // getHostNameWithoutDomain returns the machine hostname, without domain information.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/experimental/traffic_monitor/trafficopsdata/trafficopsdata.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/trafficopsdata/trafficopsdata.go b/traffic_monitor/experimental/traffic_monitor/trafficopsdata/trafficopsdata.go
index 08d3031..e12818c 100644
--- a/traffic_monitor/experimental/traffic_monitor/trafficopsdata/trafficopsdata.go
+++ b/traffic_monitor/experimental/traffic_monitor/trafficopsdata/trafficopsdata.go
@@ -1,16 +1,36 @@
 package trafficopsdata
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import (
 	"encoding/json"
 	"fmt"
-	"github.com/Comcast/traffic_control/traffic_monitor/experimental/traffic_monitor/enum"
-	towrap "github.com/Comcast/traffic_control/traffic_monitor/experimental/traffic_monitor/trafficopswrapper"
+	"github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/enum"
+	towrap "github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/trafficopswrapper"
 	"regexp"
 	"strings"
 	"sync"
 )
 
-// DsRegexes maps Delivery Service Regular Expressions to delivery services.
+// Regexes maps Delivery Service Regular Expressions to delivery services.
 // For performance, we categorize Regular Expressions into 3 categories:
 // 1. Direct string matches, with no regular expression matching characters
 // 2. .*\.foo\..* expressions, where foo is a direct string match with no regular expression matching characters
@@ -41,10 +61,12 @@ func (d Regexes) DeliveryService(fqdn string) (enum.DeliveryServiceName, bool) {
 	return "", false
 }
 
+// NewRegexes constructs a new Regexes object, initializing internal pointer members.
 func NewRegexes() Regexes {
 	return Regexes{DirectMatches: map[string]enum.DeliveryServiceName{}, DotStartSlashDotFooSlashDotDotStar: map[string]enum.DeliveryServiceName{}, RegexMatch: map[*regexp.Regexp]enum.DeliveryServiceName{}}
 }
 
+// TOData holds CDN data fetched from Traffic Ops.
 type TOData struct {
 	DeliveryServiceServers map[enum.DeliveryServiceName][]enum.CacheName
 	ServerDeliveryServices map[enum.CacheName][]enum.DeliveryServiceName
@@ -54,6 +76,7 @@ type TOData struct {
 	ServerCachegroups      map[enum.CacheName]enum.CacheGroupName
 }
 
+// New returns a new empty TOData object, initializing pointer members.
 func New() *TOData {
 	return &TOData{
 		DeliveryServiceServers: map[enum.DeliveryServiceName][]enum.CacheName{},
@@ -65,12 +88,14 @@ func New() *TOData {
 	}
 }
 
+// TODataThreadsafe provides safe access for multiple goroutine writers and one goroutine reader, to the encapsulated TOData object.
 // This could be made lock-free, if the performance was necessary
 type TODataThreadsafe struct {
 	toData *TOData
 	m      *sync.RWMutex
 }
 
+// NewThreadsafe returns a new TOData object, wrapped to be safe for multiple goroutine readers and a single writer.
 func NewThreadsafe() TODataThreadsafe {
 	return TODataThreadsafe{m: &sync.RWMutex{}, toData: New()}
 }
@@ -118,7 +143,8 @@ func (d TODataThreadsafe) Fetch(to towrap.ITrafficOpsSession, cdn string) error
 		return fmt.Errorf("Error getting CRconfig from Traffic Ops: %v", err)
 	}
 	var crConfig CRConfig
-	if err := json.Unmarshal(crConfigBytes, &crConfig); err != nil {
+	err = json.Unmarshal(crConfigBytes, &crConfig)
+	if err != nil {
 		return fmt.Errorf("Error unmarshalling CRconfig: %v", err)
 	}
 
@@ -157,7 +183,7 @@ func getDeliveryServiceServers(crc CRConfig) (map[enum.DeliveryServiceName][]enu
 	serverDses := map[enum.CacheName][]enum.DeliveryServiceName{}
 
 	for serverName, serverData := range crc.ContentServers {
-		for deliveryServiceName, _ := range serverData.DeliveryServices {
+		for deliveryServiceName := range serverData.DeliveryServices {
 			dsServers[deliveryServiceName] = append(dsServers[deliveryServiceName], serverName)
 			serverDses[serverName] = append(serverDses[serverName], deliveryServiceName)
 		}

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/experimental/traffic_monitor/trafficopswrapper/trafficopswrapper.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/trafficopswrapper/trafficopswrapper.go b/traffic_monitor/experimental/traffic_monitor/trafficopswrapper/trafficopswrapper.go
index 5250039..d8be7cc 100644
--- a/traffic_monitor/experimental/traffic_monitor/trafficopswrapper/trafficopswrapper.go
+++ b/traffic_monitor/experimental/traffic_monitor/trafficopswrapper/trafficopswrapper.go
@@ -1,27 +1,51 @@
 package trafficopswrapper
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import (
 	"fmt"
 	"sync"
 
-	to "github.com/Comcast/traffic_control/traffic_ops/client"
+	to "github.com/apache/incubator-trafficcontrol/traffic_ops/client"
 )
 
+// ITrafficOpsSession provides an interface to the Traffic Ops client, so it may be wrapped or mocked.
 type ITrafficOpsSession interface {
 	CRConfigRaw(cdn string) ([]byte, error)
 	TrafficMonitorConfigMap(cdn string) (*to.TrafficMonitorConfigMap, error)
 	Set(session *to.Session)
 }
 
+// TrafficOpsSessionThreadsafe provides access to the Traffic Ops client safe for multiple goroutines. This fulfills the ITrafficOpsSession interface.
 type TrafficOpsSessionThreadsafe struct {
 	session **to.Session // pointer-to-pointer, because we're given a pointer from the Traffic Ops package, and we don't want to copy it.
 	m       *sync.Mutex
 }
 
+// NewTrafficOpsSessionThreadsafe returns a new threadsafe TrafficOpsSessionThreadsafe wrapping the given `Session`.
 func NewTrafficOpsSessionThreadsafe(s *to.Session) TrafficOpsSessionThreadsafe {
 	return TrafficOpsSessionThreadsafe{&s, &sync.Mutex{}}
 }
 
+// CRConfigRaw returns the CRConfig from the Traffic Ops. This is safe for multiple goroutines.
 func (s TrafficOpsSessionThreadsafe) CRConfigRaw(cdn string) ([]byte, error) {
 	s.m.Lock()
 	if s.session == nil || *s.session == nil {
@@ -32,6 +56,7 @@ func (s TrafficOpsSessionThreadsafe) CRConfigRaw(cdn string) ([]byte, error) {
 	return b, e
 }
 
+// TrafficMonitorConfigMap returns the Traffic Monitor config map from the Traffic Ops. This is safe for multiple goroutines.
 func (s TrafficOpsSessionThreadsafe) TrafficMonitorConfigMap(cdn string) (*to.TrafficMonitorConfigMap, error) {
 	s.m.Lock()
 	if s.session == nil || *s.session == nil {
@@ -42,6 +67,7 @@ func (s TrafficOpsSessionThreadsafe) TrafficMonitorConfigMap(cdn string) (*to.Tr
 	return d, e
 }
 
+// Set sets the internal Traffic Ops session. This is safe for multiple goroutines, being aware they will race.
 func (s TrafficOpsSessionThreadsafe) Set(session *to.Session) {
 	s.m.Lock()
 	*s.session = session

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/experimental/traffic_monitor/version.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/version.go b/traffic_monitor/experimental/traffic_monitor/version.go
index bc6309a..3f22073 100644
--- a/traffic_monitor/experimental/traffic_monitor/version.go
+++ b/traffic_monitor/experimental/traffic_monitor/version.go
@@ -1,3 +1,24 @@
 package main
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
+// Version is the current version of the app, in string form.
 var Version = "2.2"

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/pom.xml
----------------------------------------------------------------------
diff --git a/traffic_monitor/pom.xml b/traffic_monitor/pom.xml
index eae7e46..b6887c7 100644
--- a/traffic_monitor/pom.xml
+++ b/traffic_monitor/pom.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0" encoding="UTF-8"?>
+
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
 	xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
 
@@ -6,7 +26,7 @@
 
 	<groupId>com.comcast.cdn.traffic_control</groupId>
 	<artifactId>traffic_monitor</artifactId>
-	<version>1.7.0</version>
+	<version>1.8.0</version>
 	<packaging>war</packaging>
 
 	<scm>
@@ -317,7 +337,6 @@
 							</execution>
 						</executions>
 						<configuration>
-							<copyright>2011-2014, Comcast Converged Products</copyright>
 							<group>Applications/Internet</group>
 							<release>${env.GIT_REV_COUNT}.${buildNumber}.el6</release>
 							<needarch>x86_64</needarch>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/bin/config-doc.sh
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/bin/config-doc.sh b/traffic_monitor/src/main/bin/config-doc.sh
index 5d57a00..06425e1 100644
--- a/traffic_monitor/src/main/bin/config-doc.sh
+++ b/traffic_monitor/src/main/bin/config-doc.sh
@@ -1,6 +1,5 @@
 #!/bin/bash
 #
-# Copyright 2015 Comcast Cable Communications Management, LLC
 #
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/bin/traffic_monitor_config.pl
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/bin/traffic_monitor_config.pl b/traffic_monitor/src/main/bin/traffic_monitor_config.pl
index 0bcc302..b39a65d 100755
--- a/traffic_monitor/src/main/bin/traffic_monitor_config.pl
+++ b/traffic_monitor/src/main/bin/traffic_monitor_config.pl
@@ -1,6 +1,5 @@
 #!/usr/bin/perl
 #
-# Copyright 2015 Comcast Cable Communications Management, LLC
 #
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/conf/log4j.properties b/traffic_monitor/src/main/conf/log4j.properties
index 152daac..17c0cc4 100644
--- a/traffic_monitor/src/main/conf/log4j.properties
+++ b/traffic_monitor/src/main/conf/log4j.properties
@@ -1,5 +1,4 @@
 #
-# Copyright 2015 Comcast Cable Communications Management, LLC
 #
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.html
index faf6527..95a85c9 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <head>
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.java
index f32ce2b..c3212c0 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/Index.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorApplication.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorApplication.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorApplication.java
index 1253e8b..edd65a2 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorApplication.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorApplication.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorPage.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorPage.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorPage.java
index 12bcd58..5eb78de 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorPage.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorPage.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorSession.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorSession.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorSession.java
index 5b01f9f..4222f82 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorSession.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/MonitorSession.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/StatisticModel.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/StatisticModel.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/StatisticModel.java
index 3182ace..9e0b46e 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/StatisticModel.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/StatisticModel.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Cache.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Cache.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Cache.java
index 6b2b620..8372277 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Cache.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Cache.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Config.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Config.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Config.java
index 6ae8dd9..0e1d099 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Config.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Config.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/ConfigHandler.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/ConfigHandler.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/ConfigHandler.java
index b2183c3..f825bbd 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/ConfigHandler.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/ConfigHandler.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/MonitorConfig.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/MonitorConfig.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/MonitorConfig.java
index 0a62cce..a8d2def 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/MonitorConfig.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/MonitorConfig.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Peer.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Peer.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Peer.java
index 687d27d..898e2c8 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Peer.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/Peer.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/RouterConfig.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/RouterConfig.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/RouterConfig.java
index 4593ff4..344e4bd 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/RouterConfig.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/config/RouterConfig.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataPoint.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataPoint.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataPoint.java
index f41ca28..9ac465d 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataPoint.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataPoint.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataSummary.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataSummary.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataSummary.java
index 32b3078..820b19f 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataSummary.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/DataSummary.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/StatisticsLog.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/StatisticsLog.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/StatisticsLog.java
index 6bf3995..5645532 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/StatisticsLog.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/data/StatisticsLog.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.data;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import org.apache.log4j.Logger;
 
 import java.util.Arrays;
@@ -259,4 +279,4 @@ public class StatisticsLog {
 
 		}
 	}
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/AbstractState.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/AbstractState.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/AbstractState.java
index cbae776..47fb607 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/AbstractState.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/AbstractState.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Bandwidth.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Bandwidth.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Bandwidth.java
index a86c4ee..0aea900 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Bandwidth.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Bandwidth.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheState.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheState.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheState.java
index 831473a..4d10f4a 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheState.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheState.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateRegistry.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateRegistry.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateRegistry.java
index d12dc19..dd63356 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateRegistry.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateRegistry.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import com.comcast.cdn.traffic_control.traffic_monitor.config.Cache;
 
 import static com.comcast.cdn.traffic_control.traffic_monitor.health.HealthDeterminer.AdminStatus.ADMIN_DOWN;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateUpdater.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateUpdater.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateUpdater.java
index db1fa8a..5ed444e 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateUpdater.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStateUpdater.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import com.comcast.cdn.traffic_control.traffic_monitor.wicket.models.CacheDataModel;
 import com.ning.http.client.AsyncCompletionHandler;
 import com.ning.http.client.Response;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStatisticsClient.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStatisticsClient.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStatisticsClient.java
index 703413c..206226d 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStatisticsClient.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheStatisticsClient.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import com.comcast.cdn.traffic_control.traffic_monitor.config.Cache;
 import com.ning.http.client.AsyncHttpClient;
 import com.ning.http.client.AsyncHttpClientConfig;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheWatcher.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheWatcher.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheWatcher.java
index 4c83d8d..7213465 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheWatcher.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/CacheWatcher.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DeliveryServiceStateRegistry.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DeliveryServiceStateRegistry.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DeliveryServiceStateRegistry.java
index 9445b17..c73906c 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DeliveryServiceStateRegistry.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DeliveryServiceStateRegistry.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import com.comcast.cdn.traffic_control.traffic_monitor.config.Cache;
 import com.comcast.cdn.traffic_control.traffic_monitor.data.DataPoint;
 import org.apache.log4j.Logger;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsState.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsState.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsState.java
index d5e18ab..51057b5 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsState.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsState.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsStati.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsStati.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsStati.java
index dea0dfd..016ab5e 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsStati.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsStati.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import org.apache.log4j.Logger;
 
 import java.text.DecimalFormat;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsWatcher.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsWatcher.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsWatcher.java
index bc6d37a..a3517f0 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsWatcher.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/DsWatcher.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/EmbeddedStati.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/EmbeddedStati.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/EmbeddedStati.java
index e9e98aa..22ad81d 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/EmbeddedStati.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/EmbeddedStati.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import java.util.HashMap;
 import java.util.Map;
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Event.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Event.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Event.java
index a1da815..0b9155d 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Event.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/Event.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/HealthDeterminer.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/HealthDeterminer.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/HealthDeterminer.java
index 09b5ea8..072380e 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/HealthDeterminer.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/HealthDeterminer.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerState.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerState.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerState.java
index 8ac164a..32a0988 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerState.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerState.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerWatcher.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerWatcher.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerWatcher.java
index 8ecd91f..377d497 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerWatcher.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/PeerWatcher.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/StateRegistry.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/StateRegistry.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/StateRegistry.java
index 9e07aff..9206bdd 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/StateRegistry.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/StateRegistry.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.health;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import java.util.Collection;
 import java.util.HashSet;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmListener.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmListener.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmListener.java
index e014c16..d74cd01 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmListener.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmListener.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmWatcher.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmWatcher.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmWatcher.java
index bfc545b..57819d4 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmWatcher.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/health/TmWatcher.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CacheStats.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CacheStats.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CacheStats.java
index 67a9787..74fac99 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CacheStats.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CacheStats.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/ConfigDoc.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/ConfigDoc.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/ConfigDoc.java
index 8eca7af..7462b31 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/ConfigDoc.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/ConfigDoc.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrConfig.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrConfig.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrConfig.java
index 27595ff..f59ca34 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrConfig.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrConfig.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrStates.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrStates.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrStates.java
index c554e0d..8bac0ae 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrStates.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/CrStates.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/DsStats.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/DsStats.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/DsStats.java
index 1299c55..8506185 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/DsStats.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/DsStats.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/EventLog.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/EventLog.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/EventLog.java
index c766371..1bb3f6e 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/EventLog.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/EventLog.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/JsonPage.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/JsonPage.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/JsonPage.java
index 05b21c9..4f6b0f6 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/JsonPage.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/JsonPage.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/PeerStates.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/PeerStates.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/PeerStates.java
index fc54c50..eaca64c 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/PeerStates.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/PeerStates.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/StatSummary.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/StatSummary.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/StatSummary.java
index 9936dd1..652d95f 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/StatSummary.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/StatSummary.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/Stats.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/Stats.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/Stats.java
index ab6096f..f85941b 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/Stats.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/publish/Stats.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Fetcher.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Fetcher.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Fetcher.java
index 590a083..ee38261 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Fetcher.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Fetcher.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Network.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Network.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Network.java
index 39cdfa1..0456c0a 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Network.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Network.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/PeriodicResourceUpdater.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/PeriodicResourceUpdater.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/PeriodicResourceUpdater.java
index 6b01f5e..bfd9265 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/PeriodicResourceUpdater.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/PeriodicResourceUpdater.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/StableBloomFilter.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/StableBloomFilter.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/StableBloomFilter.java
index 4aebf2d..bde7dc5 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/StableBloomFilter.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/StableBloomFilter.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Updatable.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Updatable.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Updatable.java
index 15b59cf..fbaae70 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Updatable.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/util/Updatable.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/AbstractMultiAjaxBehavior.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/AbstractMultiAjaxBehavior.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/AbstractMultiAjaxBehavior.java
index 33ff0dd..60d3fa9 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/AbstractMultiAjaxBehavior.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/AbstractMultiAjaxBehavior.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/MultiUpdatingTimerBehavior.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/MultiUpdatingTimerBehavior.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/MultiUpdatingTimerBehavior.java
index 5ddf467..6101faf 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/MultiUpdatingTimerBehavior.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/MultiUpdatingTimerBehavior.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/UpdatingAttributeAppender.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/UpdatingAttributeAppender.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/UpdatingAttributeAppender.java
index 07b21d8..97f42d9 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/UpdatingAttributeAppender.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/behaviors/UpdatingAttributeAppender.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.html
index 1617879..11d10ff 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <head>
 <title wicket:id="hostname">>Traffic Monitor - Details Page</title>
@@ -18,4 +37,4 @@
 		</div>
 	</div>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.java
index 17a4f3b..ed77dda 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheDetailsPage.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.html
index 24405c6..69f152a 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <body>
 	<wicket:head>
@@ -30,4 +49,4 @@
 		</table>
 	</wicket:panel>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.java
index a13cdac..4e42dad 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/CacheListPanel.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.html
index dd7c7bb..33d9428 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <head>
 <title wicket:id="id">>Traffic Monitor - Details Page</title>
@@ -18,4 +37,4 @@
 		</div>
 	</div>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.java
index 99b0459..28d946a 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsDetailsPage.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.html
index 66fe395..2320f76 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <body>
 	<wicket:head>
@@ -38,4 +57,4 @@
 		</table>
 	</wicket:panel>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.java
index a366cae..a8a4069 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/DsListPanel.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.html
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.html b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.html
index 11e88e1..7980481 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.html
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.html
@@ -1,3 +1,22 @@
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <html>
 <body>
 	<wicket:head>
@@ -37,4 +56,4 @@
 		</table>
 	</wicket:panel>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.java
index f01de5e..129fd86 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/EventLogPanel.java
@@ -1,5 +1,4 @@
 /*
- * Copyright 2015 Comcast Cable Communications Management, LLC
  *
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/be5ab888/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/StateDetailsPage.java
----------------------------------------------------------------------
diff --git a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/StateDetailsPage.java b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/StateDetailsPage.java
index f16de4a..24bb233 100644
--- a/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/StateDetailsPage.java
+++ b/traffic_monitor/src/main/java/com/comcast/cdn/traffic_control/traffic_monitor/wicket/components/StateDetailsPage.java
@@ -1,5 +1,25 @@
 package com.comcast.cdn.traffic_control.traffic_monitor.wicket.components;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+
 import com.comcast.cdn.traffic_control.traffic_monitor.StatisticModel;
 import com.comcast.cdn.traffic_control.traffic_monitor.MonitorPage;
 import com.comcast.cdn.traffic_control.traffic_monitor.health.StateRegistry;