You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficcontrol.apache.org by el...@apache.org on 2017/01/26 16:45:07 UTC

[3/4] incubator-trafficcontrol git commit: cleaned up logging

cleaned up logging

(cherry picked from commit b2d8e2dd5ea413f0aa130ec5ce2491ae658ada6c)


Project: http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/commit/3082e83e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/tree/3082e83e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/diff/3082e83e

Branch: refs/heads/master
Commit: 3082e83ef991ae0eedaf1d2f75cf53f835e7db54
Parents: 246e2e6
Author: David Neuman <da...@gmail.com>
Authored: Tue Jan 24 10:29:54 2017 -0700
Committer: Jeff Elsloo <je...@cable.comcast.com>
Committed: Thu Jan 26 09:44:15 2017 -0700

----------------------------------------------------------------------
 .../experimental/common/handler/handler.go      |  7 +++----
 .../experimental/common/poller/poller.go        | 10 ++++-----
 .../experimental/traffic_monitor/cache/cache.go | 16 +++++---------
 .../traffic_monitor/deliveryservice/stat.go     | 18 ++++++++--------
 .../traffic_monitor/manager/datarequest.go      | 22 ++++++++++----------
 .../traffic_monitor/manager/health.go           |  5 ++---
 .../traffic_monitor/manager/manager.go          |  1 -
 .../traffic_monitor/manager/monitorconfig.go    |  7 ++++++-
 .../traffic_monitor/manager/stat.go             | 12 ++---------
 .../traffic_monitor/threadsafe/polledcaches.go  |  4 ++--
 10 files changed, 45 insertions(+), 57 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/common/handler/handler.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/common/handler/handler.go b/traffic_monitor/experimental/common/handler/handler.go
index 312553a..f83ef43 100644
--- a/traffic_monitor/experimental/common/handler/handler.go
+++ b/traffic_monitor/experimental/common/handler/handler.go
@@ -8,9 +8,9 @@ package handler
  * 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
@@ -19,7 +19,6 @@ package handler
  * under the License.
  */
 
-
 import (
 	"encoding/json"
 	"io"
@@ -61,7 +60,7 @@ func (handler OpsConfigFileHandler) Listen() {
 		err := json.Unmarshal(result.([]byte), &toc)
 
 		if err != nil {
-			log.Errorf("unmarshalling JSON: %s\n", err)
+			log.Errorf("Could not unmarshal Ops Config JSON: %s\n", err)
 		} else {
 			handler.OpsConfigChannel <- toc
 		}

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/common/poller/poller.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/common/poller/poller.go b/traffic_monitor/experimental/common/poller/poller.go
index 65288fc..67f6784 100644
--- a/traffic_monitor/experimental/common/poller/poller.go
+++ b/traffic_monitor/experimental/common/poller/poller.go
@@ -61,7 +61,7 @@ type HttpPollerConfig struct {
 	noSleep bool
 }
 
-// Creates and returns a new HttpPoller.
+// NewHTTP creates and returns a new HttpPoller.
 // If tick is false, HttpPoller.TickChan() will return nil. If noSleep is true, the poller will busywait instead of sleeping, and use a single goroutine which dispatches polls instead of a goroutine per poll.
 func NewHTTP(
 	interval time.Duration,
@@ -134,7 +134,7 @@ func (p MonitorConfigPoller) Poll() {
 				if err != nil {
 					log.Errorf("MonitorConfigPoller: %s\n %v\n", err, monitorConfig)
 				} else {
-					log.Infoln("MonitorConfigPoller: fetched monitorConfig")
+					log.Debugln("MonitorConfigPoller: fetched monitorConfig")
 					p.ConfigChannel <- *monitorConfig
 				}
 			} else {
@@ -156,10 +156,10 @@ type HTTPPollInfo struct {
 
 func (p HttpPoller) Poll() {
 	if p.Config.noSleep {
-		log.Infof("HttpPoller using InsomniacPoll\n")
+		log.Debugf("HttpPoller using InsomniacPoll\n")
 		p.InsomniacPoll()
 	} else {
-		log.Infof("HttpPoller using SleepPoll\n")
+		log.Debugf("HttpPoller using SleepPoll\n")
 		p.SleepPoll()
 	}
 }
@@ -213,7 +213,7 @@ func sleepPoller(interval time.Duration, id string, url string, fetcher fetcher.
 			realInterval := time.Now().Sub(lastTime)
 			if realInterval > interval+(time.Millisecond*100) {
 				instr.TimerFail.Inc()
-				log.Infof("Intended Duration: %v Actual Duration: %v\n", interval, realInterval)
+				log.Debugf("Intended Duration: %v Actual Duration: %v\n", interval, realInterval)
 			}
 			lastTime = time.Now()
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/cache/cache.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/cache/cache.go b/traffic_monitor/experimental/traffic_monitor/cache/cache.go
index a0b6b60..98b996b 100644
--- a/traffic_monitor/experimental/traffic_monitor/cache/cache.go
+++ b/traffic_monitor/experimental/traffic_monitor/cache/cache.go
@@ -292,14 +292,14 @@ func (handler Handler) Handle(id string, r io.Reader, reqTime time.Duration, req
 	}
 
 	if reqErr != nil {
-		log.Errorf("%v handler given error '%v'\n", id, reqErr) // error here, in case the thing that called Handle didn't error
+		log.Warnf("%v handler given error '%v'\n", id, reqErr) // error here, in case the thing that called Handle didn't error
 		result.Error = reqErr
 		handler.resultChan <- result
 		return
 	}
 
 	if r == nil {
-		log.Errorf("%v handle reader nil\n", id)
+		log.Warnf("%v handle reader nil\n", id)
 		result.Error = fmt.Errorf("handler got nil reader")
 		handler.resultChan <- result
 		return
@@ -309,7 +309,7 @@ func (handler Handler) Handle(id string, r io.Reader, reqTime time.Duration, req
 	result.PrecomputedData.Time = result.Time
 
 	if decodeErr := json.NewDecoder(r).Decode(&result.Astats); decodeErr != nil {
-		log.Errorf("%s procnetdev decode error '%v'\n", id, decodeErr)
+		log.Warnf("%s procnetdev decode error '%v'\n", id, decodeErr)
 		result.Error = decodeErr
 		handler.resultChan <- result
 		return
@@ -323,8 +323,6 @@ func (handler Handler) Handle(id string, r io.Reader, reqTime time.Duration, req
 		log.Warnf("addkbps %s inf.speed empty\n", id)
 	}
 
-	log.Debugf("poll %v %v handle decode end\n", pollID, time.Now())
-
 	if reqErr != nil {
 		result.Error = reqErr
 		log.Errorf("addkbps handle %s error '%v'\n", id, reqErr)
@@ -333,13 +331,10 @@ func (handler Handler) Handle(id string, r io.Reader, reqTime time.Duration, req
 	}
 
 	if handler.Precompute() {
-		log.Debugf("poll %v %v handle precompute start\n", pollID, time.Now())
 		result = handler.precompute(result)
-		log.Debugf("poll %v %v handle precompute end\n", pollID, time.Now())
 	}
-	log.Debugf("poll %v %v handle write start\n", pollID, time.Now())
+
 	handler.resultChan <- result
-	log.Debugf("poll %v %v handle end\n", pollID, time.Now())
 }
 
 // outBytes takes the proc.net.dev string, and the interface name, and returns the bytes field
@@ -386,7 +381,7 @@ func (handler Handler) precompute(result Result) Result {
 		var err error
 		stats, err = processStat(result.ID, stats, todata, stat, value, result.Time)
 		if err != nil && err != dsdata.ErrNotProcessedStat {
-			log.Errorf("precomputing cache %v stat %v value %v error %v", result.ID, stat, value, err)
+			log.Infof("precomputing cache %v stat %v value %v error %v", result.ID, stat, value, err)
 			result.PrecomputedData.Errors = append(result.PrecomputedData.Errors, err)
 		}
 	}
@@ -506,7 +501,6 @@ func addCacheStat(stat *dsdata.StatCacheStats, name string, val interface{}) err
 		}
 		stat.OutBytes.Value += int64(v)
 	case "is_available":
-		log.Debugln("got is_available")
 		v, ok := val.(bool)
 		if !ok {
 			return fmt.Errorf("stat '%s' value expected bool actual '%v' type %T", name, val, val)

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/deliveryservice/stat.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/deliveryservice/stat.go b/traffic_monitor/experimental/traffic_monitor/deliveryservice/stat.go
index b377a26..c1d8cba 100644
--- a/traffic_monitor/experimental/traffic_monitor/deliveryservice/stat.go
+++ b/traffic_monitor/experimental/traffic_monitor/deliveryservice/stat.go
@@ -78,29 +78,29 @@ func addAvailableData(dsStats Stats, crStates peer.Crstates, serverCachegroups m
 	for cache, available := range crStates.Caches {
 		cacheGroup, ok := serverCachegroups[cache]
 		if !ok {
-			log.Warnf("CreateStats not adding availability data for '%s': not found in Cachegroups\n", cache)
+			log.Infof("CreateStats not adding availability data for '%s': not found in Cachegroups\n", cache)
 			continue
 		}
 		deliveryServices, ok := serverDs[cache]
 		if !ok {
-			log.Warnf("CreateStats not adding availability data for '%s': not found in DeliveryServices\n", cache)
+			log.Infof("CreateStats not adding availability data for '%s': not found in DeliveryServices\n", cache)
 			continue
 		}
 		cacheType, ok := serverTypes[cache]
 		if !ok {
-			log.Warnf("CreateStats not adding availability data for '%s': not found in Server Types\n", cache)
+			log.Infof("CreateStats not adding availability data for '%s': not found in Server Types\n", cache)
 			continue
 		}
 
 		for _, deliveryService := range deliveryServices {
 			if deliveryService == "" {
-				log.Errorf("EMPTY addAvailableData DS") // various bugs in other functions can cause this - this will help identify and debug them.
+				log.Errorln("EMPTY addAvailableData DS") // various bugs in other functions can cause this - this will help identify and debug them.
 				continue
 			}
 
 			stat, ok := dsStats.DeliveryService[deliveryService]
 			if !ok {
-				log.Warnf("CreateStats not adding availability data for '%s': not found in Stats\n", cache)
+				log.Infof("CreateStats not adding availability data for '%s': not found in Stats\n", cache)
 				continue // TODO log warning? Error?
 			}
 
@@ -304,13 +304,13 @@ func addLastDSStatTotals(lastStat LastDSStat, cachesReporting map[enum.CacheName
 		if cacheGroup, ok := serverCachegroups[cacheName]; ok {
 			cacheGroups[cacheGroup] = cacheGroups[cacheGroup].Sum(cacheStats)
 		} else {
-			log.Errorf("while computing delivery service data, cache %v not in cachegroups\n", cacheName)
+			log.Warnf("while computing delivery service data, cache %v not in cachegroups\n", cacheName)
 		}
 
 		if cacheType, ok := serverTypes[cacheName]; ok {
 			cacheTypes[cacheType] = cacheTypes[cacheType].Sum(cacheStats)
 		} else {
-			log.Errorf("while computing delivery service data, cache %v not in types\n", cacheName)
+			log.Warnf("while computing delivery service data, cache %v not in types\n", cacheName)
 		}
 		total = total.Sum(cacheStats)
 	}
@@ -331,7 +331,7 @@ func addDSPerSecStats(dsName enum.DeliveryServiceName, stat dsdata.Stat, lastSta
 	for cacheName, cacheStats := range stat.Caches {
 		lastStat.Caches[cacheName], err = addLastStats(lastStat.Caches[cacheName], cacheStats, dsStatsTime)
 		if err != nil {
-			log.Errorf("%v adding kbps for cache %v: %v", dsName, cacheName, err)
+			log.Warnf("%v adding kbps for cache %v: %v", dsName, cacheName, err)
 			continue
 		}
 		cacheStats.Kbps.Value = lastStat.Caches[cacheName].Bytes.PerSec / BytesPerKilobit
@@ -376,7 +376,7 @@ func addCachePerSecStats(cacheName enum.CacheName, precomputed cache.Precomputed
 	lastStat := lastStats.Caches[cacheName] // if lastStats.Caches[cacheName] doesn't exist, it will be zero-constructed, and `addLastStat` will refrain from setting the PerSec for zero LastStats
 	lastStat.Bytes, err = addLastStat(lastStat.Bytes, outBytes, outBytesTime)
 	if err != nil {
-		log.Errorf("while computing delivery service data for cache %v: %v\n", cacheName, err)
+		log.Warnf("while computing delivery service data for cache %v: %v\n", cacheName, err)
 		return lastStats
 	}
 	lastStats.Caches[cacheName] = lastStat

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/manager/datarequest.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/manager/datarequest.go b/traffic_monitor/experimental/traffic_monitor/manager/datarequest.go
index 7712154..1c99eb3 100644
--- a/traffic_monitor/experimental/traffic_monitor/manager/datarequest.go
+++ b/traffic_monitor/experimental/traffic_monitor/manager/datarequest.go
@@ -897,12 +897,12 @@ func createCacheStatuses(
 	for cacheName, cacheType := range cacheTypes {
 		infoHistory, ok := statInfoHistory[cacheName]
 		if !ok {
-			log.Warnf("createCacheStatuses stat info history missing cache %s\n", cacheName)
+			log.Infof("createCacheStatuses stat info history missing cache %s\n", cacheName)
 			continue
 		}
 
 		if len(infoHistory) < 1 {
-			log.Warnf("createCacheStatuses stat info history empty for cache %s\n", cacheName)
+			log.Infof("createCacheStatuses stat info history empty for cache %s\n", cacheName)
 			continue
 		}
 
@@ -912,32 +912,32 @@ func createCacheStatuses(
 
 		healthQueryTime, err := latestQueryTimeMS(cacheName, lastHealthDurations)
 		if err != nil {
-			log.Warnf("Error getting cache %v health query time: %v\n", cacheName, err)
+			log.Infof("Error getting cache %v health query time: %v\n", cacheName, err)
 		}
 
 		statTime, err := latestResultInfoTimeMS(cacheName, statInfoHistory)
 		if err != nil {
-			log.Warnf("Error getting cache %v stat result time: %v\n", cacheName, err)
+			log.Infof("Error getting cache %v stat result time: %v\n", cacheName, err)
 		}
 
 		healthTime, err := latestResultTimeMS(cacheName, healthHistory)
 		if err != nil {
-			log.Warnf("Error getting cache %v health result time: %v\n", cacheName, err)
+			log.Infof("Error getting cache %v health result time: %v\n", cacheName, err)
 		}
 
 		statSpan, err := infoResultSpanMS(cacheName, statInfoHistory)
 		if err != nil {
-			log.Warnf("Error getting cache %v stat span: %v\n", cacheName, err)
+			log.Infof("Error getting cache %v stat span: %v\n", cacheName, err)
 		}
 
 		healthSpan, err := resultSpanMS(cacheName, healthHistory)
 		if err != nil {
-			log.Warnf("Error getting cache %v health span: %v\n", cacheName, err)
+			log.Infof("Error getting cache %v health span: %v\n", cacheName, err)
 		}
 
 		var kbps *float64
 		if lastStat, ok := lastStats.Caches[cacheName]; !ok {
-			log.Warnf("cache not in last kbps cache %s\n", cacheName)
+			log.Infof("cache not in last kbps cache %s\n", cacheName)
 		} else {
 			kbpsVal := lastStat.Bytes.PerSec / float64(ds.BytesPerKilobit)
 			kbps = &kbpsVal
@@ -945,7 +945,7 @@ func createCacheStatuses(
 
 		var maxKbps *float64
 		if v, ok := maxKbpses[cacheName]; !ok {
-			log.Warnf("cache not in max kbps cache %s\n", cacheName)
+			log.Infof("cache not in max kbps cache %s\n", cacheName)
 		} else {
 			fv := float64(v)
 			maxKbps = &fv
@@ -954,7 +954,7 @@ func createCacheStatuses(
 		var connections *int64
 		connectionsVal, ok := conns[cacheName]
 		if !ok {
-			log.Warnf("cache not in connections %s\n", cacheName)
+			log.Infof("cache not in connections %s\n", cacheName)
 		} else {
 			connections = &connectionsVal
 		}
@@ -963,7 +963,7 @@ func createCacheStatuses(
 		var statusPoller *string
 		statusVal, ok := localCacheStatus[cacheName]
 		if !ok {
-			log.Warnf("cache not in statuses %s\n", cacheName)
+			log.Infof("cache not in statuses %s\n", cacheName)
 		} else {
 			statusString := statusVal.Status + " - "
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/manager/health.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/manager/health.go b/traffic_monitor/experimental/traffic_monitor/manager/health.go
index e2657f8..a4465cf 100644
--- a/traffic_monitor/experimental/traffic_monitor/manager/health.go
+++ b/traffic_monitor/experimental/traffic_monitor/manager/health.go
@@ -159,7 +159,7 @@ func healthResultManagerListen(
 		for {
 			select {
 			case <-ticker.C:
-				log.Warnf("Health Result Manager flushing queued results\n")
+				log.Infof("Health Result Manager flushing queued results\n")
 				process(results)
 				break innerLoop
 			default:
@@ -207,7 +207,6 @@ func processHealthResult(
 	monitorConfigCopy := monitorConfig.Get()
 	healthHistoryCopy := healthHistory.Get().Copy()
 	for i, healthResult := range results {
-		log.Debugf("poll %v %v healthresultman start\n", healthResult.PollID, time.Now())
 		fetchCount.Inc()
 		var prevResult cache.Result
 		healthResultHistory := healthHistoryCopy[healthResult.ID]
@@ -222,7 +221,7 @@ func processHealthResult(
 
 		maxHistory := uint64(monitorConfigCopy.Profile[monitorConfigCopy.TrafficServer[string(healthResult.ID)].Profile].Parameters.HistoryCount)
 		if maxHistory < 1 {
-			log.Warnf("processHealthResult got history count %v for %v, setting to 1\n", maxHistory, healthResult.ID)
+			log.Infof("processHealthResult got history count %v for %v, setting to 1\n", maxHistory, healthResult.ID)
 			maxHistory = 1
 		}
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/manager/manager.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/manager/manager.go b/traffic_monitor/experimental/traffic_monitor/manager/manager.go
index 974b3eb..c869365 100644
--- a/traffic_monitor/experimental/traffic_monitor/manager/manager.go
+++ b/traffic_monitor/experimental/traffic_monitor/manager/manager.go
@@ -34,7 +34,6 @@ import (
 	"github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/threadsafe"
 	todata "github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/trafficopsdata"
 	towrap "github.com/apache/incubator-trafficcontrol/traffic_monitor/experimental/traffic_monitor/trafficopswrapper"
-	//	to "github.com/apache/incubator-trafficcontrol/traffic_ops/client"
 	"github.com/davecheney/gmx"
 )
 

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/manager/monitorconfig.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/manager/monitorconfig.go b/traffic_monitor/experimental/traffic_monitor/manager/monitorconfig.go
index f524a3c..76350d4 100644
--- a/traffic_monitor/experimental/traffic_monitor/manager/monitorconfig.go
+++ b/traffic_monitor/experimental/traffic_monitor/manager/monitorconfig.go
@@ -137,6 +137,8 @@ func trafficOpsHealthPollIntervalToDuration(t int) time.Duration {
 	return time.Duration(t) * time.Millisecond
 }
 
+var healthPollCount int
+
 // getPollIntervals reads the Traffic Ops Client monitorConfig structure, and parses and returns the health, peer, and stat poll intervals
 func getHealthPeerStatPollIntervals(monitorConfig to.TrafficMonitorConfigMap, cfg config.Config) (time.Duration, time.Duration, time.Duration, error) {
 	peerPollIntervalI, peerPollIntervalExists := monitorConfig.Config["peers.polling.interval"]
@@ -162,7 +164,10 @@ func getHealthPeerStatPollIntervals(monitorConfig to.TrafficMonitorConfigMap, cf
 	healthPollIntervalI, healthPollIntervalExists := monitorConfig.Config["heartbeat.polling.interval"]
 	healthPollIntervalInt, healthPollIntervalIsInt := healthPollIntervalI.(float64)
 	if !healthPollIntervalExists {
-		log.Warnf("Traffic Ops Monitor config missing 'heartbeat.polling.interval', using health for heartbeat.\n")
+		if healthPollCount == 0 { //only log this once
+			log.Warnln("Traffic Ops Monitor config missing 'heartbeat.polling.interval', using health for heartbeat.")
+			healthPollCount++
+		}
 		healthPollIntervalInt = statPollIntervalInt
 	} else if !healthPollIntervalIsInt {
 		log.Warnf("Traffic Ops Monitor config 'heartbeat.polling.interval' value '%v' type %T is not an integer, using health for heartbeat\n", statPollIntervalI, statPollIntervalI)

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/manager/stat.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/manager/stat.go b/traffic_monitor/experimental/traffic_monitor/manager/stat.go
index 8e69bda..8d3404a 100644
--- a/traffic_monitor/experimental/traffic_monitor/manager/stat.go
+++ b/traffic_monitor/experimental/traffic_monitor/manager/stat.go
@@ -105,7 +105,7 @@ func StartStatHistoryManager(
 				case <-cachesChanged:
 					unpolledCaches.SetNewCaches(getNewCaches(localStates, monitorConfig))
 				case <-ticker.C:
-					log.Warnf("StatHistoryManager flushing queued results\n")
+					log.Infof("StatHistoryManager flushing queued results\n")
 					process(results)
 					break innerLoop
 				default:
@@ -162,7 +162,7 @@ func processStatResults(
 	for i, result := range results {
 		maxStats := uint64(mc.Profile[mc.TrafficServer[string(result.ID)].Profile].Parameters.HistoryCount)
 		if maxStats < 1 {
-			log.Warnf("processStatResults got history count %v for %v, setting to 1\n", maxStats, result.ID)
+			log.Infof("processStatResults got history count %v for %v, setting to 1\n", maxStats, result.ID)
 			maxStats = 1
 		}
 
@@ -194,16 +194,8 @@ func processStatResults(
 	statResultHistoryThreadsafe.Set(statResultHistory)
 	statMaxKbpsesThreadsafe.Set(statMaxKbpses)
 
-	for _, result := range results {
-		log.Debugf("poll %v %v CreateStats start\n", result.PollID, time.Now())
-	}
-
 	newDsStats, newLastStats, err := ds.CreateStats(precomputedData, toData, combinedStates, lastStats.Get().Copy(), time.Now(), mc)
 
-	for _, result := range results {
-		log.Debugf("poll %v %v CreateStats end\n", result.PollID, time.Now())
-	}
-
 	if err != nil {
 		errorCount.Inc()
 		log.Errorf("getting deliveryservice: %v\n", err)

http://git-wip-us.apache.org/repos/asf/incubator-trafficcontrol/blob/3082e83e/traffic_monitor/experimental/traffic_monitor/threadsafe/polledcaches.go
----------------------------------------------------------------------
diff --git a/traffic_monitor/experimental/traffic_monitor/threadsafe/polledcaches.go b/traffic_monitor/experimental/traffic_monitor/threadsafe/polledcaches.go
index 978021f..9276de4 100644
--- a/traffic_monitor/experimental/traffic_monitor/threadsafe/polledcaches.go
+++ b/traffic_monitor/experimental/traffic_monitor/threadsafe/polledcaches.go
@@ -120,7 +120,7 @@ func (t *UnpolledCaches) SetPolled(results []cache.Result, lastStats ds.LastStat
 			}
 
 			if !result.Available || result.Error != nil {
-				log.Infof("polled %v\n", cache)
+				log.Debugf("polled %v\n", cache)
 				delete(unpolledCaches, cache)
 				break innerLoop
 			}
@@ -130,7 +130,7 @@ func (t *UnpolledCaches) SetPolled(results []cache.Result, lastStats ds.LastStat
 			continue
 		}
 		if lastStat.Bytes.PerSec != 0 {
-			log.Infof("polled %v\n", cache)
+			log.Debugf("polled %v\n", cache)
 			delete(unpolledCaches, cache)
 		}
 	}