1 /*
2  * Copyright (C) 2017 The Android Open Source Project
3  *
4  * Licensed under the Apache License, Version 2.0 (the "License");
5  * you may not use this file except in compliance with the License.
6  * You may obtain a copy of the License at
7  *
8  *      http://www.apache.org/licenses/LICENSE-2.0
9  *
10  * Unless required by applicable law or agreed to in writing, software
11  * distributed under the License is distributed on an "AS IS" BASIS,
12  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
13  * See the License for the specific language governing permissions and
14  * limitations under the License.
15  */
16 #define DEBUG false  // STOPSHIP if true
17 #include "Log.h"
18 
19 #include "MetricsManager.h"
20 
21 #include <private/android_filesystem_config.h>
22 
23 #include "CountMetricProducer.h"
24 #include "condition/CombinationConditionTracker.h"
25 #include "condition/SimpleConditionTracker.h"
26 #include "guardrail/StatsdStats.h"
27 #include "matchers/CombinationLogMatchingTracker.h"
28 #include "matchers/SimpleLogMatchingTracker.h"
29 #include "metrics_manager_util.h"
30 #include "state/StateManager.h"
31 #include "stats_log_util.h"
32 #include "stats_util.h"
33 #include "statslog_statsd.h"
34 
35 using android::util::FIELD_COUNT_REPEATED;
36 using android::util::FIELD_TYPE_INT32;
37 using android::util::FIELD_TYPE_INT64;
38 using android::util::FIELD_TYPE_MESSAGE;
39 using android::util::FIELD_TYPE_STRING;
40 using android::util::ProtoOutputStream;
41 
42 using std::set;
43 using std::string;
44 using std::vector;
45 
46 namespace android {
47 namespace os {
48 namespace statsd {
49 
50 const int FIELD_ID_METRICS = 1;
51 const int FIELD_ID_ANNOTATIONS = 7;
52 const int FIELD_ID_ANNOTATIONS_INT64 = 1;
53 const int FIELD_ID_ANNOTATIONS_INT32 = 2;
54 
55 // for ActiveConfig
56 const int FIELD_ID_ACTIVE_CONFIG_ID = 1;
57 const int FIELD_ID_ACTIVE_CONFIG_UID = 2;
58 const int FIELD_ID_ACTIVE_CONFIG_METRIC = 3;
59 
MetricsManager(const ConfigKey & key,const StatsdConfig & config,const int64_t timeBaseNs,const int64_t currentTimeNs,const sp<UidMap> & uidMap,const sp<StatsPullerManager> & pullerManager,const sp<AlarmMonitor> & anomalyAlarmMonitor,const sp<AlarmMonitor> & periodicAlarmMonitor)60 MetricsManager::MetricsManager(const ConfigKey& key, const StatsdConfig& config,
61                                const int64_t timeBaseNs, const int64_t currentTimeNs,
62                                const sp<UidMap>& uidMap,
63                                const sp<StatsPullerManager>& pullerManager,
64                                const sp<AlarmMonitor>& anomalyAlarmMonitor,
65                                const sp<AlarmMonitor>& periodicAlarmMonitor)
66     : mConfigKey(key),
67       mUidMap(uidMap),
68       mTtlNs(config.has_ttl_in_seconds() ? config.ttl_in_seconds() * NS_PER_SEC : -1),
69       mTtlEndNs(-1),
70       mLastReportTimeNs(currentTimeNs),
71       mLastReportWallClockNs(getWallClockNs()),
72       mPullerManager(pullerManager),
73       mWhitelistedAtomIds(config.whitelisted_atom_ids().begin(),
74                           config.whitelisted_atom_ids().end()),
75       mShouldPersistHistory(config.persist_locally()) {
76     // Init the ttl end timestamp.
77     refreshTtl(timeBaseNs);
78 
79     mConfigValid = initStatsdConfig(
80             key, config, *uidMap, pullerManager, anomalyAlarmMonitor, periodicAlarmMonitor,
81             timeBaseNs, currentTimeNs, mTagIds, mAllAtomMatchers, mAllConditionTrackers,
82             mAllMetricProducers, mAllAnomalyTrackers, mAllPeriodicAlarmTrackers,
83             mConditionToMetricMap, mTrackerToMetricMap, mTrackerToConditionMap,
84             mActivationAtomTrackerToMetricMap, mDeactivationAtomTrackerToMetricMap,
85             mAlertTrackerMap, mMetricIndexesWithActivation, mNoReportMetricIds);
86 
87     mHashStringsInReport = config.hash_strings_in_metric_report();
88     mVersionStringsInReport = config.version_strings_in_metric_report();
89     mInstallerInReport = config.installer_in_metric_report();
90 
91     // Init allowed pushed atom uids.
92     if (config.allowed_log_source_size() == 0) {
93         mConfigValid = false;
94         ALOGE("Log source whitelist is empty! This config won't get any data. Suggest adding at "
95                       "least AID_SYSTEM and AID_STATSD to the allowed_log_source field.");
96     } else {
97         for (const auto& source : config.allowed_log_source()) {
98             auto it = UidMap::sAidToUidMapping.find(source);
99             if (it != UidMap::sAidToUidMapping.end()) {
100                 mAllowedUid.push_back(it->second);
101             } else {
102                 mAllowedPkg.push_back(source);
103             }
104         }
105 
106         if (mAllowedUid.size() + mAllowedPkg.size() > StatsdStats::kMaxLogSourceCount) {
107             ALOGE("Too many log sources. This is likely to be an error in the config.");
108             mConfigValid = false;
109         } else {
110             initLogSourceWhiteList();
111         }
112     }
113 
114     // Init default allowed pull atom uids.
115     int numPullPackages = 0;
116     for (const string& pullSource : config.default_pull_packages()) {
117         auto it = UidMap::sAidToUidMapping.find(pullSource);
118         if (it != UidMap::sAidToUidMapping.end()) {
119             numPullPackages++;
120             mDefaultPullUids.insert(it->second);
121         } else {
122             ALOGE("Default pull atom packages must be in sAidToUidMapping");
123             mConfigValid = false;
124         }
125     }
126     // Init per-atom pull atom packages.
127     for (const PullAtomPackages& pullAtomPackages : config.pull_atom_packages()) {
128         int32_t atomId = pullAtomPackages.atom_id();
129         for (const string& pullPackage : pullAtomPackages.packages()) {
130             numPullPackages++;
131             auto it = UidMap::sAidToUidMapping.find(pullPackage);
132             if (it != UidMap::sAidToUidMapping.end()) {
133                 mPullAtomUids[atomId].insert(it->second);
134             } else {
135                 mPullAtomPackages[atomId].insert(pullPackage);
136             }
137         }
138     }
139     if (numPullPackages > StatsdStats::kMaxPullAtomPackages) {
140         ALOGE("Too many sources in default_pull_packages and pull_atom_packages. This is likely to "
141               "be an error in the config");
142         mConfigValid = false;
143     } else {
144         initPullAtomSources();
145     }
146     mPullerManager->RegisterPullUidProvider(mConfigKey, this);
147 
148     // Store the sub-configs used.
149     for (const auto& annotation : config.annotation()) {
150         mAnnotations.emplace_back(annotation.field_int64(), annotation.field_int32());
151     }
152 
153     // Guardrail. Reject the config if it's too big.
154     if (mAllMetricProducers.size() > StatsdStats::kMaxMetricCountPerConfig ||
155         mAllConditionTrackers.size() > StatsdStats::kMaxConditionCountPerConfig ||
156         mAllAtomMatchers.size() > StatsdStats::kMaxMatcherCountPerConfig) {
157         ALOGE("This config is too big! Reject!");
158         mConfigValid = false;
159     }
160     if (mAllAnomalyTrackers.size() > StatsdStats::kMaxAlertCountPerConfig) {
161         ALOGE("This config has too many alerts! Reject!");
162         mConfigValid = false;
163     }
164 
165     mIsAlwaysActive = (mMetricIndexesWithActivation.size() != mAllMetricProducers.size()) ||
166             (mAllMetricProducers.size() == 0);
167     bool isActive = mIsAlwaysActive;
168     for (int metric : mMetricIndexesWithActivation) {
169         isActive |= mAllMetricProducers[metric]->isActive();
170     }
171     mIsActive = isActive;
172     VLOG("mIsActive is initialized to %d", mIsActive)
173 
174     // no matter whether this config is valid, log it in the stats.
175     StatsdStats::getInstance().noteConfigReceived(
176             key, mAllMetricProducers.size(), mAllConditionTrackers.size(), mAllAtomMatchers.size(),
177             mAllAnomalyTrackers.size(), mAnnotations, mConfigValid);
178     // Check active
179     for (const auto& metric : mAllMetricProducers) {
180         if (metric->isActive()) {
181             mIsActive = true;
182             break;
183         }
184     }
185 }
186 
~MetricsManager()187 MetricsManager::~MetricsManager() {
188     for (auto it : mAllMetricProducers) {
189         for (int atomId : it->getSlicedStateAtoms()) {
190             StateManager::getInstance().unregisterListener(atomId, it);
191         }
192     }
193     mPullerManager->UnregisterPullUidProvider(mConfigKey, this);
194 
195     VLOG("~MetricsManager()");
196 }
197 
initLogSourceWhiteList()198 void MetricsManager::initLogSourceWhiteList() {
199     std::lock_guard<std::mutex> lock(mAllowedLogSourcesMutex);
200     mAllowedLogSources.clear();
201     mAllowedLogSources.insert(mAllowedUid.begin(), mAllowedUid.end());
202 
203     for (const auto& pkg : mAllowedPkg) {
204         auto uids = mUidMap->getAppUid(pkg);
205         mAllowedLogSources.insert(uids.begin(), uids.end());
206     }
207     if (DEBUG) {
208         for (const auto& uid : mAllowedLogSources) {
209             VLOG("Allowed uid %d", uid);
210         }
211     }
212 }
213 
initPullAtomSources()214 void MetricsManager::initPullAtomSources() {
215     std::lock_guard<std::mutex> lock(mAllowedLogSourcesMutex);
216     mCombinedPullAtomUids.clear();
217     for (const auto& [atomId, uids] : mPullAtomUids) {
218         mCombinedPullAtomUids[atomId].insert(uids.begin(), uids.end());
219     }
220     for (const auto& [atomId, packages] : mPullAtomPackages) {
221         for (const string& pkg : packages) {
222             set<int32_t> uids = mUidMap->getAppUid(pkg);
223             mCombinedPullAtomUids[atomId].insert(uids.begin(), uids.end());
224         }
225     }
226 }
227 
isConfigValid() const228 bool MetricsManager::isConfigValid() const {
229     return mConfigValid;
230 }
231 
notifyAppUpgrade(const int64_t & eventTimeNs,const string & apk,const int uid,const int64_t version)232 void MetricsManager::notifyAppUpgrade(const int64_t& eventTimeNs, const string& apk, const int uid,
233                                       const int64_t version) {
234     // Inform all metric producers.
235     for (const auto& it : mAllMetricProducers) {
236         it->notifyAppUpgrade(eventTimeNs);
237     }
238     // check if we care this package
239     if (std::find(mAllowedPkg.begin(), mAllowedPkg.end(), apk) != mAllowedPkg.end()) {
240         // We will re-initialize the whole list because we don't want to keep the multi mapping of
241         // UID<->pkg inside MetricsManager to reduce the memory usage.
242         initLogSourceWhiteList();
243     }
244 
245     for (const auto& it : mPullAtomPackages) {
246         if (it.second.find(apk) != it.second.end()) {
247             initPullAtomSources();
248             return;
249         }
250     }
251 }
252 
notifyAppRemoved(const int64_t & eventTimeNs,const string & apk,const int uid)253 void MetricsManager::notifyAppRemoved(const int64_t& eventTimeNs, const string& apk,
254                                       const int uid) {
255     // Inform all metric producers.
256     for (const auto& it : mAllMetricProducers) {
257         it->notifyAppRemoved(eventTimeNs);
258     }
259     // check if we care this package
260     if (std::find(mAllowedPkg.begin(), mAllowedPkg.end(), apk) != mAllowedPkg.end()) {
261         // We will re-initialize the whole list because we don't want to keep the multi mapping of
262         // UID<->pkg inside MetricsManager to reduce the memory usage.
263         initLogSourceWhiteList();
264     }
265 
266     for (const auto& it : mPullAtomPackages) {
267         if (it.second.find(apk) != it.second.end()) {
268             initPullAtomSources();
269             return;
270         }
271     }
272 }
273 
onUidMapReceived(const int64_t & eventTimeNs)274 void MetricsManager::onUidMapReceived(const int64_t& eventTimeNs) {
275     // Purposefully don't inform metric producers on a new snapshot
276     // because we don't need to flush partial buckets.
277     // This occurs if a new user is added/removed or statsd crashes.
278     initPullAtomSources();
279 
280     if (mAllowedPkg.size() == 0) {
281         return;
282     }
283     initLogSourceWhiteList();
284 }
285 
onStatsdInitCompleted(const int64_t & eventTimeNs)286 void MetricsManager::onStatsdInitCompleted(const int64_t& eventTimeNs) {
287     // Inform all metric producers.
288     for (const auto& it : mAllMetricProducers) {
289         it->onStatsdInitCompleted(eventTimeNs);
290     }
291 }
292 
init()293 void MetricsManager::init() {
294     for (const auto& producer : mAllMetricProducers) {
295         producer->prepareFirstBucket();
296     }
297 }
298 
getPullAtomUids(int32_t atomId)299 vector<int32_t> MetricsManager::getPullAtomUids(int32_t atomId) {
300     std::lock_guard<std::mutex> lock(mAllowedLogSourcesMutex);
301     vector<int32_t> uids;
302     const auto& it = mCombinedPullAtomUids.find(atomId);
303     if (it != mCombinedPullAtomUids.end()) {
304         uids.insert(uids.end(), it->second.begin(), it->second.end());
305     }
306     uids.insert(uids.end(), mDefaultPullUids.begin(), mDefaultPullUids.end());
307     return uids;
308 }
309 
dumpStates(FILE * out,bool verbose)310 void MetricsManager::dumpStates(FILE* out, bool verbose) {
311     fprintf(out, "ConfigKey %s, allowed source:", mConfigKey.ToString().c_str());
312     {
313         std::lock_guard<std::mutex> lock(mAllowedLogSourcesMutex);
314         for (const auto& source : mAllowedLogSources) {
315             fprintf(out, "%d ", source);
316         }
317     }
318     fprintf(out, "\n");
319     for (const auto& producer : mAllMetricProducers) {
320         producer->dumpStates(out, verbose);
321     }
322 }
323 
dropData(const int64_t dropTimeNs)324 void MetricsManager::dropData(const int64_t dropTimeNs) {
325     for (const auto& producer : mAllMetricProducers) {
326         producer->dropData(dropTimeNs);
327     }
328 }
329 
onDumpReport(const int64_t dumpTimeStampNs,const bool include_current_partial_bucket,const bool erase_data,const DumpLatency dumpLatency,std::set<string> * str_set,ProtoOutputStream * protoOutput)330 void MetricsManager::onDumpReport(const int64_t dumpTimeStampNs,
331                                   const bool include_current_partial_bucket,
332                                   const bool erase_data,
333                                   const DumpLatency dumpLatency,
334                                   std::set<string> *str_set,
335                                   ProtoOutputStream* protoOutput) {
336     VLOG("=========================Metric Reports Start==========================");
337     // one StatsLogReport per MetricProduer
338     for (const auto& producer : mAllMetricProducers) {
339         if (mNoReportMetricIds.find(producer->getMetricId()) == mNoReportMetricIds.end()) {
340             uint64_t token = protoOutput->start(
341                     FIELD_TYPE_MESSAGE | FIELD_COUNT_REPEATED | FIELD_ID_METRICS);
342             if (mHashStringsInReport) {
343                 producer->onDumpReport(dumpTimeStampNs, include_current_partial_bucket, erase_data,
344                                        dumpLatency, str_set, protoOutput);
345             } else {
346                 producer->onDumpReport(dumpTimeStampNs, include_current_partial_bucket, erase_data,
347                                        dumpLatency, nullptr, protoOutput);
348             }
349             protoOutput->end(token);
350         } else {
351             producer->clearPastBuckets(dumpTimeStampNs);
352         }
353     }
354     for (const auto& annotation : mAnnotations) {
355         uint64_t token = protoOutput->start(FIELD_TYPE_MESSAGE | FIELD_COUNT_REPEATED |
356                                             FIELD_ID_ANNOTATIONS);
357         protoOutput->write(FIELD_TYPE_INT64 | FIELD_ID_ANNOTATIONS_INT64,
358                            (long long)annotation.first);
359         protoOutput->write(FIELD_TYPE_INT32 | FIELD_ID_ANNOTATIONS_INT32, annotation.second);
360         protoOutput->end(token);
361     }
362 
363     // Do not update the timestamps when data is not cleared to avoid timestamps from being
364     // misaligned.
365     if (erase_data) {
366         mLastReportTimeNs = dumpTimeStampNs;
367         mLastReportWallClockNs = getWallClockNs();
368     }
369     VLOG("=========================Metric Reports End==========================");
370 }
371 
372 
checkLogCredentials(const LogEvent & event)373 bool MetricsManager::checkLogCredentials(const LogEvent& event) {
374     if (mWhitelistedAtomIds.find(event.GetTagId()) != mWhitelistedAtomIds.end()) {
375         return true;
376     }
377     std::lock_guard<std::mutex> lock(mAllowedLogSourcesMutex);
378     if (mAllowedLogSources.find(event.GetUid()) == mAllowedLogSources.end()) {
379         VLOG("log source %d not on the whitelist", event.GetUid());
380         return false;
381     }
382     return true;
383 }
384 
eventSanityCheck(const LogEvent & event)385 bool MetricsManager::eventSanityCheck(const LogEvent& event) {
386     if (event.GetTagId() == util::APP_BREADCRUMB_REPORTED) {
387         // Check that app breadcrumb reported fields are valid.
388         status_t err = NO_ERROR;
389 
390         // Uid is 3rd from last field and must match the caller's uid,
391         // unless that caller is statsd itself (statsd is allowed to spoof uids).
392         long appHookUid = event.GetLong(event.size()-2, &err);
393         if (err != NO_ERROR) {
394             VLOG("APP_BREADCRUMB_REPORTED had error when parsing the uid");
395             return false;
396         }
397 
398         // Because the uid within the LogEvent may have been mapped from
399         // isolated to host, map the loggerUid similarly before comparing.
400         int32_t loggerUid = mUidMap->getHostUidOrSelf(event.GetUid());
401         if (loggerUid != appHookUid && loggerUid != AID_STATSD) {
402             VLOG("APP_BREADCRUMB_REPORTED has invalid uid: claimed %ld but caller is %d",
403                  appHookUid, loggerUid);
404             return false;
405         }
406 
407         // The state must be from 0,3. This part of code must be manually updated.
408         long appHookState = event.GetLong(event.size(), &err);
409         if (err != NO_ERROR) {
410             VLOG("APP_BREADCRUMB_REPORTED had error when parsing the state field");
411             return false;
412         } else if (appHookState < 0 || appHookState > 3) {
413             VLOG("APP_BREADCRUMB_REPORTED does not have valid state %ld", appHookState);
414             return false;
415         }
416     } else if (event.GetTagId() == util::DAVEY_OCCURRED) {
417         // Daveys can be logged from any app since they are logged in libs/hwui/JankTracker.cpp.
418         // Check that the davey duration is reasonable. Max length check is for privacy.
419         status_t err = NO_ERROR;
420 
421         // Uid is the first field provided.
422         long jankUid = event.GetLong(1, &err);
423         if (err != NO_ERROR) {
424             VLOG("Davey occurred had error when parsing the uid");
425             return false;
426         }
427         int32_t loggerUid = event.GetUid();
428         if (loggerUid != jankUid && loggerUid != AID_STATSD) {
429             VLOG("DAVEY_OCCURRED has invalid uid: claimed %ld but caller is %d", jankUid,
430                  loggerUid);
431             return false;
432         }
433 
434         long duration = event.GetLong(event.size(), &err);
435         if (err != NO_ERROR) {
436             VLOG("Davey occurred had error when parsing the duration");
437             return false;
438         } else if (duration > 100000) {
439             VLOG("Davey duration is unreasonably long: %ld", duration);
440             return false;
441         }
442     }
443 
444     return true;
445 }
446 
447 // Consume the stats log if it's interesting to this metric.
onLogEvent(const LogEvent & event)448 void MetricsManager::onLogEvent(const LogEvent& event) {
449     if (!mConfigValid) {
450         return;
451     }
452 
453     if (!checkLogCredentials(event)) {
454         return;
455     }
456 
457     if (!eventSanityCheck(event)) {
458         return;
459     }
460 
461     int tagId = event.GetTagId();
462     int64_t eventTimeNs = event.GetElapsedTimestampNs();
463 
464     bool isActive = mIsAlwaysActive;
465 
466     // Set of metrics that are still active after flushing.
467     unordered_set<int> activeMetricsIndices;
468 
469     // Update state of all metrics w/ activation conditions as of eventTimeNs.
470     for (int metricIndex : mMetricIndexesWithActivation) {
471         const sp<MetricProducer>& metric = mAllMetricProducers[metricIndex];
472         metric->flushIfExpire(eventTimeNs);
473         if (metric->isActive()) {
474             // If this metric w/ activation condition is still active after
475             // flushing, remember it.
476             activeMetricsIndices.insert(metricIndex);
477         }
478     }
479 
480     mIsActive = isActive || !activeMetricsIndices.empty();
481 
482     if (mTagIds.find(tagId) == mTagIds.end()) {
483         // Not interesting...
484         return;
485     }
486 
487     vector<MatchingState> matcherCache(mAllAtomMatchers.size(), MatchingState::kNotComputed);
488 
489     // Evaluate all atom matchers.
490     for (auto& matcher : mAllAtomMatchers) {
491         matcher->onLogEvent(event, mAllAtomMatchers, matcherCache);
492     }
493 
494     // Set of metrics that received an activation cancellation.
495     unordered_set<int> metricIndicesWithCanceledActivations;
496 
497     // Determine which metric activations received a cancellation and cancel them.
498     for (const auto& it : mDeactivationAtomTrackerToMetricMap) {
499         if (matcherCache[it.first] == MatchingState::kMatched) {
500             for (int metricIndex : it.second) {
501                 mAllMetricProducers[metricIndex]->cancelEventActivation(it.first);
502                 metricIndicesWithCanceledActivations.insert(metricIndex);
503             }
504         }
505     }
506 
507     // Determine whether any metrics are no longer active after cancelling metric activations.
508     for (const int metricIndex : metricIndicesWithCanceledActivations) {
509         const sp<MetricProducer>& metric = mAllMetricProducers[metricIndex];
510         metric->flushIfExpire(eventTimeNs);
511         if (!metric->isActive()) {
512             activeMetricsIndices.erase(metricIndex);
513         }
514     }
515 
516     isActive |= !activeMetricsIndices.empty();
517 
518 
519     // Determine which metric activations should be turned on and turn them on
520     for (const auto& it : mActivationAtomTrackerToMetricMap) {
521         if (matcherCache[it.first] == MatchingState::kMatched) {
522             for (int metricIndex : it.second) {
523                 mAllMetricProducers[metricIndex]->activate(it.first, eventTimeNs);
524                 isActive |= mAllMetricProducers[metricIndex]->isActive();
525             }
526         }
527     }
528 
529     mIsActive = isActive;
530 
531     // A bitmap to see which ConditionTracker needs to be re-evaluated.
532     vector<bool> conditionToBeEvaluated(mAllConditionTrackers.size(), false);
533 
534     for (const auto& pair : mTrackerToConditionMap) {
535         if (matcherCache[pair.first] == MatchingState::kMatched) {
536             const auto& conditionList = pair.second;
537             for (const int conditionIndex : conditionList) {
538                 conditionToBeEvaluated[conditionIndex] = true;
539             }
540         }
541     }
542 
543     vector<ConditionState> conditionCache(mAllConditionTrackers.size(),
544                                           ConditionState::kNotEvaluated);
545     // A bitmap to track if a condition has changed value.
546     vector<bool> changedCache(mAllConditionTrackers.size(), false);
547     for (size_t i = 0; i < mAllConditionTrackers.size(); i++) {
548         if (conditionToBeEvaluated[i] == false) {
549             continue;
550         }
551         sp<ConditionTracker>& condition = mAllConditionTrackers[i];
552         condition->evaluateCondition(event, matcherCache, mAllConditionTrackers, conditionCache,
553                                      changedCache);
554     }
555 
556     for (size_t i = 0; i < mAllConditionTrackers.size(); i++) {
557         if (changedCache[i] == false) {
558             continue;
559         }
560         auto pair = mConditionToMetricMap.find(i);
561         if (pair != mConditionToMetricMap.end()) {
562             auto& metricList = pair->second;
563             for (auto metricIndex : metricList) {
564                 // Metric cares about non sliced condition, and it's changed.
565                 // Push the new condition to it directly.
566                 if (!mAllMetricProducers[metricIndex]->isConditionSliced()) {
567                     mAllMetricProducers[metricIndex]->onConditionChanged(conditionCache[i],
568                                                                          eventTimeNs);
569                     // Metric cares about sliced conditions, and it may have changed. Send
570                     // notification, and the metric can query the sliced conditions that are
571                     // interesting to it.
572                 } else {
573                     mAllMetricProducers[metricIndex]->onSlicedConditionMayChange(conditionCache[i],
574                                                                                  eventTimeNs);
575                 }
576             }
577         }
578     }
579 
580     // For matched AtomMatchers, tell relevant metrics that a matched event has come.
581     for (size_t i = 0; i < mAllAtomMatchers.size(); i++) {
582         if (matcherCache[i] == MatchingState::kMatched) {
583             StatsdStats::getInstance().noteMatcherMatched(mConfigKey,
584                                                           mAllAtomMatchers[i]->getId());
585             auto pair = mTrackerToMetricMap.find(i);
586             if (pair != mTrackerToMetricMap.end()) {
587                 auto& metricList = pair->second;
588                 for (const int metricIndex : metricList) {
589                     // pushed metrics are never scheduled pulls
590                     mAllMetricProducers[metricIndex]->onMatchedLogEvent(i, event);
591                 }
592             }
593         }
594     }
595 }
596 
onAnomalyAlarmFired(const int64_t & timestampNs,unordered_set<sp<const InternalAlarm>,SpHash<InternalAlarm>> & alarmSet)597 void MetricsManager::onAnomalyAlarmFired(
598         const int64_t& timestampNs,
599         unordered_set<sp<const InternalAlarm>, SpHash<InternalAlarm>>& alarmSet) {
600     for (const auto& itr : mAllAnomalyTrackers) {
601         itr->informAlarmsFired(timestampNs, alarmSet);
602     }
603 }
604 
onPeriodicAlarmFired(const int64_t & timestampNs,unordered_set<sp<const InternalAlarm>,SpHash<InternalAlarm>> & alarmSet)605 void MetricsManager::onPeriodicAlarmFired(
606         const int64_t& timestampNs,
607         unordered_set<sp<const InternalAlarm>, SpHash<InternalAlarm>>& alarmSet) {
608     for (const auto& itr : mAllPeriodicAlarmTrackers) {
609         itr->informAlarmsFired(timestampNs, alarmSet);
610     }
611 }
612 
613 // Returns the total byte size of all metrics managed by a single config source.
byteSize()614 size_t MetricsManager::byteSize() {
615     size_t totalSize = 0;
616     for (const auto& metricProducer : mAllMetricProducers) {
617         totalSize += metricProducer->byteSize();
618     }
619     return totalSize;
620 }
621 
loadActiveConfig(const ActiveConfig & config,int64_t currentTimeNs)622 void MetricsManager::loadActiveConfig(const ActiveConfig& config, int64_t currentTimeNs) {
623     if (config.metric_size() == 0) {
624         ALOGW("No active metric for config %s", mConfigKey.ToString().c_str());
625         return;
626     }
627 
628     for (int i = 0; i < config.metric_size(); i++) {
629         const auto& activeMetric = config.metric(i);
630         for (int metricIndex : mMetricIndexesWithActivation) {
631             const auto& metric = mAllMetricProducers[metricIndex];
632             if (metric->getMetricId() == activeMetric.id()) {
633                 VLOG("Setting active metric: %lld", (long long)metric->getMetricId());
634                 metric->loadActiveMetric(activeMetric, currentTimeNs);
635                 if (!mIsActive && metric->isActive()) {
636                     StatsdStats::getInstance().noteActiveStatusChanged(mConfigKey,
637                                                                        /*activate=*/ true);
638                 }
639                 mIsActive |= metric->isActive();
640             }
641         }
642     }
643 }
644 
writeActiveConfigToProtoOutputStream(int64_t currentTimeNs,const DumpReportReason reason,ProtoOutputStream * proto)645 void MetricsManager::writeActiveConfigToProtoOutputStream(
646         int64_t currentTimeNs, const DumpReportReason reason, ProtoOutputStream* proto) {
647     proto->write(FIELD_TYPE_INT64 | FIELD_ID_ACTIVE_CONFIG_ID, (long long)mConfigKey.GetId());
648     proto->write(FIELD_TYPE_INT32 | FIELD_ID_ACTIVE_CONFIG_UID, mConfigKey.GetUid());
649     for (int metricIndex : mMetricIndexesWithActivation) {
650         const auto& metric = mAllMetricProducers[metricIndex];
651         const uint64_t metricToken = proto->start(FIELD_TYPE_MESSAGE | FIELD_COUNT_REPEATED |
652                 FIELD_ID_ACTIVE_CONFIG_METRIC);
653         metric->writeActiveMetricToProtoOutputStream(currentTimeNs, reason, proto);
654         proto->end(metricToken);
655     }
656 }
657 
writeMetadataToProto(int64_t currentWallClockTimeNs,int64_t systemElapsedTimeNs,metadata::StatsMetadata * statsMetadata)658 bool MetricsManager::writeMetadataToProto(int64_t currentWallClockTimeNs,
659                                           int64_t systemElapsedTimeNs,
660                                           metadata::StatsMetadata* statsMetadata) {
661     bool metadataWritten = false;
662     metadata::ConfigKey* configKey = statsMetadata->mutable_config_key();
663     configKey->set_config_id(mConfigKey.GetId());
664     configKey->set_uid(mConfigKey.GetUid());
665     for (const auto& anomalyTracker : mAllAnomalyTrackers) {
666         metadata::AlertMetadata* alertMetadata = statsMetadata->add_alert_metadata();
667         bool alertWritten = anomalyTracker->writeAlertMetadataToProto(currentWallClockTimeNs,
668                 systemElapsedTimeNs, alertMetadata);
669         if (!alertWritten) {
670             statsMetadata->mutable_alert_metadata()->RemoveLast();
671         }
672         metadataWritten |= alertWritten;
673     }
674     return metadataWritten;
675 }
676 
loadMetadata(const metadata::StatsMetadata & metadata,int64_t currentWallClockTimeNs,int64_t systemElapsedTimeNs)677 void MetricsManager::loadMetadata(const metadata::StatsMetadata& metadata,
678                                   int64_t currentWallClockTimeNs,
679                                   int64_t systemElapsedTimeNs) {
680     for (const metadata::AlertMetadata& alertMetadata : metadata.alert_metadata()) {
681         int64_t alertId = alertMetadata.alert_id();
682         auto it = mAlertTrackerMap.find(alertId);
683         if (it == mAlertTrackerMap.end()) {
684             ALOGE("No anomalyTracker found for alertId %lld", (long long) alertId);
685             continue;
686         }
687         mAllAnomalyTrackers[it->second]->loadAlertMetadata(alertMetadata,
688                                                            currentWallClockTimeNs,
689                                                            systemElapsedTimeNs);
690     }
691 }
692 
693 }  // namespace statsd
694 }  // namespace os
695 }  // namespace android
696