summaryrefslogtreecommitdiff
diff options
context:
space:
mode:
authorJan Lehnardt <jan@apache.org>2009-02-22 15:31:19 +0000
committerJan Lehnardt <jan@apache.org>2009-02-22 15:31:19 +0000
commitf93232d61839019e45155cb9eb037caa24d791be (patch)
treeb768a2ee8450b5716ae4f12e8538cb7cfc956342
parent598eee1cf5979b61171f623da7e3164244ca3792 (diff)
add missing files
git-svn-id: https://svn.apache.org/repos/asf/couchdb/trunk@746734 13f79535-47bb-0310-9956-ffa450edef68
-rw-r--r--src/couchdb/couch_httpd_stats_handlers.erl41
-rw-r--r--src/couchdb/couch_stats.hrl21
-rw-r--r--src/couchdb/couch_stats_aggregator.erl325
-rw-r--r--src/couchdb/couch_stats_collector.erl127
4 files changed, 514 insertions, 0 deletions
diff --git a/src/couchdb/couch_httpd_stats_handlers.erl b/src/couchdb/couch_httpd_stats_handlers.erl
new file mode 100644
index 00000000..0b136be9
--- /dev/null
+++ b/src/couchdb/couch_httpd_stats_handlers.erl
@@ -0,0 +1,41 @@
+% Licensed 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.
+
+-module(couch_httpd_stats_handlers).
+-include("couch_db.hrl").
+-include("couch_stats.hrl").
+
+-export([handle_stats_req/1]).
+-import(couch_httpd,
+ [send_json/2,send_json/3,send_json/4,send_method_not_allowed/2,
+ start_json_response/2,send_chunk/2,end_json_response/1,
+ start_chunked_response/3, send_error/4]).
+
+-define(b2a(V), list_to_atom(binary_to_list(V))).
+
+handle_stats_req(#httpd{method='GET', path_parts=[_]}=Req) ->
+ send_json(Req, couch_stats_aggregator:all());
+
+handle_stats_req(#httpd{method='GET', path_parts=[_Stats, Module, Key]}=Req) ->
+ Time = parse_stats_query(Req),
+ Stats = couch_stats_aggregator:get_json({?b2a(Module), ?b2a(Key)}, Time),
+ Response = {[{Module, {[{Key, Stats}]}}]},
+ send_json(Req, Response);
+
+handle_stats_req(Req) ->
+ send_method_not_allowed(Req, "GET").
+
+parse_stats_query(Req) ->
+ case couch_httpd:qs(Req) of
+ [{"range", Time}] -> list_to_atom(Time);
+ _ -> '0'
+ end.
diff --git a/src/couchdb/couch_stats.hrl b/src/couchdb/couch_stats.hrl
new file mode 100644
index 00000000..7b51aa0c
--- /dev/null
+++ b/src/couchdb/couch_stats.hrl
@@ -0,0 +1,21 @@
+% Licensed 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.
+
+-record(aggregates, {
+ min=0,
+ max=0,
+ mean=0.0,
+ variance = 0.0,
+ stddev=0.0,
+ count=0,
+ last=0
+}).
diff --git a/src/couchdb/couch_stats_aggregator.erl b/src/couchdb/couch_stats_aggregator.erl
new file mode 100644
index 00000000..97f6bc14
--- /dev/null
+++ b/src/couchdb/couch_stats_aggregator.erl
@@ -0,0 +1,325 @@
+% Licensed 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.
+
+-module(couch_stats_aggregator).
+-include("couch_stats.hrl").
+
+-behaviour(gen_server).
+
+-export([init/1, handle_call/3, handle_cast/2, handle_info/2,
+ terminate/2, code_change/3]).
+
+-export([start/0, stop/0,
+ get/1, get/2, get_json/1, get_json/2, all/0,
+ time_passed/0, clear_aggregates/1]).
+
+-record(state, {
+ aggregates = []
+}).
+
+-define(COLLECTOR, couch_stats_collector).
+-define(QUEUE_MAX_LENGTH, 900). % maximimum number of seconds
+
+% PUBLIC API
+
+start() ->
+ gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
+
+stop() ->
+ gen_server:call(?MODULE, stop).
+
+get(Key) ->
+ gen_server:call(?MODULE, {get, Key}).
+get(Key, Time) ->
+ gen_server:call(?MODULE, {get, Key, Time}).
+
+get_json(Key) ->
+ gen_server:call(?MODULE, {get_json, Key}).
+get_json(Key, Time) ->
+ gen_server:call(?MODULE, {get_json, Key, Time}).
+
+time_passed() ->
+ gen_server:call(?MODULE, time_passed).
+
+clear_aggregates(Time) ->
+ gen_server:call(?MODULE, {clear_aggregates, Time}).
+
+all() ->
+ gen_server:call(?MODULE, all).
+
+% GEN_SERVER
+
+init(_) ->
+ ets:new(?MODULE, [named_table, set, protected]),
+ init_timers(),
+ {ok, #state{}}.
+
+handle_call({get, Key}, _, State) ->
+ Value = get_aggregate(Key, State),
+ {reply, Value, State};
+
+handle_call({get, Key, Time}, _, State) ->
+ Value = get_aggregate(Key, State, Time),
+ {reply, Value, State};
+
+handle_call({get_json, Key}, _, State) ->
+ Value = aggregate_to_json_term(get_aggregate(Key, State)),
+ {reply, Value, State};
+
+handle_call({get_json, Key, Time}, _, State) ->
+ Value = aggregate_to_json_term(get_aggregate(Key, State, Time)),
+ {reply, Value, State};
+
+handle_call(time_passed, _, OldState) ->
+
+ % the foldls below could probably be refactored into a less code-duping form
+
+ % update aggregates on incremental counters
+ NextState = lists:foldl(fun(Counter, State) ->
+ {Key, Value} = Counter,
+ update_aggregates_loop(Key, Value, State, incremental)
+ end, OldState, ?COLLECTOR:all(incremental)),
+
+ % update aggregates on absolute value counters
+ NewState = lists:foldl(fun(Counter, State) ->
+ {Key, Value} = Counter,
+ % clear the counter, we've got the important bits in State
+ ?COLLECTOR:clear(Key),
+ update_aggregates_loop(Key, Value, State, absolute)
+ end, NextState, ?COLLECTOR:all(absolute)),
+
+ {reply, ok, NewState};
+
+handle_call({clear_aggregates, Time}, _, State) ->
+ {reply, ok, do_clear_aggregates(Time, State)};
+
+handle_call(all, _ , State) ->
+ Results = do_get_all(State),
+ {reply, Results, State};
+
+handle_call(stop, _, State) ->
+ {stop, normal, stopped, State}.
+
+
+% PRIVATE API
+
+% Stats = [{Key, TimesProplist}]
+% TimesProplist = [{Time, Aggrgates}]
+% Aggregates = #aggregates{}
+%
+% [
+% {Key, [
+% {TimeA, #aggregates{}},
+% {TimeB, #aggregates{}},
+% {TimeC, #aggregates{}},
+% {TimeD, #aggregates{}}
+% ]
+% },
+%
+% ]
+
+%% clear the aggregats record for a specific Time = 60 | 300 | 900
+do_clear_aggregates(Time, #state{aggregates=Stats}) ->
+ NewStats = lists:map(fun({Key, TimesProplist}) ->
+ {Key, case proplists:lookup(Time, TimesProplist) of
+ % do have stats for this key, if we don't, return Stat unmodified
+ none ->
+ TimesProplist;
+ % there are stats, let's unset the Time one
+ {_Time, _Stat} ->
+ [{Time, #aggregates{}} | proplists:delete(Time, TimesProplist)]
+ end}
+ end, Stats),
+ #state{aggregates=NewStats}.
+
+%% default Time is 0, which is when CouchDB started
+get_aggregate(Key, State) ->
+ get_aggregate(Key, State, '0').
+get_aggregate(Key, #state{aggregates=StatsList}, Time) ->
+ Aggregates = case proplists:lookup(Key, StatsList) of
+ % if we don't have any data here, return an empty record
+ none -> #aggregates{};
+ {Key, Stats} ->
+ case proplists:lookup(Time, Stats) of
+ none -> #aggregates{}; % empty record again
+ {Time, Stat} -> Stat
+ end
+ end,
+ Aggregates.
+
+%% updates all aggregates for Key
+update_aggregates_loop(Key, Values, State, CounterType) ->
+ #state{aggregates=AllStats} = State,
+ % if we don't have any aggregates yet, put a list of empty atoms in
+ % so we can loop over them in update_aggregates().
+ % [{{httpd,requests},
+ % [{'0',{aggregates,1,1,1,0,0,1,1}},
+ % {'60',{aggregates,1,1,1,0,0,1,1}},
+ % {'300',{aggregates,1,1,1,0,0,1,1}},
+ % {'900',{aggregates,1,1,1,0,0,1,1}}]}]
+ [{_Key, StatsList}] = case proplists:lookup(Key, AllStats) of
+ none -> [{Key, [
+ {'0', empty},
+ {'60', empty},
+ {'300', empty},
+ {'900', empty}
+ ]}];
+ AllStatsMatch ->
+ [AllStatsMatch]
+ end,
+
+ % if we get called with a single value, wrap in in a list
+ ValuesList = case is_list(Values) of
+ false -> [Values];
+ _True -> Values
+ end,
+
+ % loop over all Time's
+ NewStats = lists:map(fun({Time, Stats}) ->
+ % loop over all values for Key
+ lists:foldl(fun(Value, Stat) ->
+ {Time, update_aggregates(Value, Stat, CounterType)}
+ end, Stats, ValuesList)
+ end, StatsList),
+
+ % put the newly calculated aggregates into State and delete the previous
+ % entry
+ #state{aggregates=[{Key, NewStats} | proplists:delete(Key, AllStats)]}.
+
+% does the actual updating of the aggregate record
+update_aggregates(Value, Stat, CounterType) ->
+ case Stat of
+ % the first time this is called, we don't have to calculate anything
+ % we just populate the record with Value
+ empty -> #aggregates{
+ min=Value,
+ max=Value,
+ mean=Value,
+ variance=0,
+ stddev=0,
+ count=1,
+ last=Value
+ };
+ % this sure could look nicer -- any ideas?
+ StatsRecord ->
+ #aggregates{
+ min=Min,
+ max=Max,
+ mean=Mean,
+ variance=Variance,
+ count=Count,
+ last=Last
+ } = StatsRecord,
+
+ % incremental counters need to keep track of the last update's value
+ NewValue = case CounterType of
+ incremental -> Value - Last;
+ absolute -> Value
+ end,
+ % Knuth, The Art of Computer Programming, vol. 2, p. 232.
+ NewCount = Count + 1,
+ NewMean = Mean + (NewValue - Mean) / NewCount, % NewCount is never 0.
+ NewVariance = Variance + (NewValue - Mean) * (NewValue - NewMean),
+ #aggregates{
+ min=lists:min([NewValue, Min]),
+ max=lists:max([NewValue, Max]),
+ mean=NewMean,
+ variance=NewVariance,
+ stddev=math:sqrt(NewVariance / NewCount),
+ count=NewCount,
+ last=Value
+ }
+ end.
+
+
+aggregate_to_json_term(#aggregates{min=Min,max=Max,mean=Mean,stddev=Stddev,count=Count}) ->
+ {[
+ % current is redundant, but reads nicer in JSON
+ {current, Count},
+ {count, Count},
+ {mean, Mean},
+ {min, Min},
+ {max, Max},
+ {stddev, Stddev},
+ {resolution, 1}
+ ]}.
+
+get_stats(Key, State) ->
+ aggregate_to_json_term(get_aggregate(Key, State)).
+
+% convert ets2list() list into JSON-erlang-terms.
+% Thanks to Paul Davis
+do_get_all(#state{aggregates=Stats}=State) ->
+ case Stats of
+ [] -> {[{ok, no_stats_yet}]};
+ _ ->
+ [{LastMod, LastVals} | LastRestMods] = lists:foldl(fun({{Module, Key}, _Count}, AccIn) ->
+ case AccIn of
+ [] ->
+ [{Module, [{Key, get_stats({Module, Key}, State)}]}];
+ [{Module, PrevVals} | RestMods] ->
+ [{Module, [{Key, get_stats({Module, Key}, State)} | PrevVals]} | RestMods];
+ [{OtherMod, ModVals} | RestMods] ->
+ [{Module, [{Key, get_stats({Module, Key}, State)}]}, {OtherMod, {lists:reverse(ModVals)}} | RestMods]
+ end
+ end, [], lists:sort(Stats)),
+ {[{LastMod, {lists:sort(LastVals)}} | LastRestMods]}
+ end.
+
+% Timer
+
+init_timers() ->
+
+ % OTP docs on timer: http://erlang.org/doc/man/timer.html
+ % start() -> ok
+ % Starts the timer server. Normally, the server does not need to be
+ % started explicitly. It is started dynamically if it is needed. This is
+ % useful during development, but in a target system the server should be
+ % started explicitly. Use configuration parameters for kernel for this.
+ %
+ % TODO: Add timer_start to kernel start options.
+
+
+ % start timers every second, minute, five minutes and fifteen minutes
+ % in the rare event of a timer death, couch_stats_aggregator will die,
+ % too and restarted by the supervision tree, all stats (for the last
+ % fifteen minutes) are gone.
+
+ {ok, _} = timer:apply_interval(1000, ?MODULE, time_passed, []),
+ {ok, _} = timer:apply_interval(6000, ?MODULE, clear_aggregates, ['60']),
+ {ok, _} = timer:apply_interval(30000, ?MODULE, clear_aggregates, ['300']),
+ {ok, _} = timer:apply_interval(90000, ?MODULE, clear_aggregates, ['900']).
+
+
+% Unused gen_server behaviour API functions that we need to declare.
+
+%% @doc Unused
+handle_cast(foo, State) ->
+ {noreply, State}.
+
+handle_info(_Info, State) ->
+ {noreply, State}.
+
+%% @doc Unused
+terminate(_Reason, _State) -> ok.
+
+%% @doc Unused
+code_change(_OldVersion, State, _Extra) -> {ok, State}.
+
+
+%% Tests
+
+-ifdef(TEST).
+% Internal API unit tests go here
+
+
+-endif. \ No newline at end of file
diff --git a/src/couchdb/couch_stats_collector.erl b/src/couchdb/couch_stats_collector.erl
new file mode 100644
index 00000000..8d0234bb
--- /dev/null
+++ b/src/couchdb/couch_stats_collector.erl
@@ -0,0 +1,127 @@
+% Licensed 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.
+
+% todo
+% - remove existance check on increment(), decrement() and record(). have
+% modules initialize counters on startup.
+
+-module(couch_stats_collector).
+
+-behaviour(gen_server).
+
+-export([init/1, handle_call/3, handle_cast/2, handle_info/2,
+ terminate/2, code_change/3]).
+
+
+-export([start/0, stop/0, get/1,
+ increment/1, decrement/1,
+ record/2, clear/1,
+ all/0, all/1]).
+
+-record(state, {}).
+
+-define(ABSOLUTE_VALUE_COUNTER_TABLE, abs_table).
+-define(HIT_COUNTER_TABLE, hit_table).
+
+
+% PUBLIC API
+
+start() ->
+ gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
+
+stop() ->
+ gen_server:call(?MODULE, stop).
+
+get(Key) ->
+ case ets:lookup(?HIT_COUNTER_TABLE, Key) of
+ [] ->
+ case ets:lookup(?ABSOLUTE_VALUE_COUNTER_TABLE, Key) of
+ [] ->
+ 0;
+ Result2 -> extract_value_from_ets_result(Key, Result2)
+ end;
+ [{_,Result1}] -> Result1
+ end.
+
+increment({Module, Key}) when is_integer(Key) ->
+ increment({Module, list_to_atom(integer_to_list(Key))});
+increment(Key) ->
+ case catch ets:update_counter(?HIT_COUNTER_TABLE, Key, 1) of
+ {'EXIT', {badarg, _}} -> ets:insert(?HIT_COUNTER_TABLE, {Key, 1});
+ _ -> ok
+ end.
+
+decrement(Key) ->
+ case catch ets:update_counter(?HIT_COUNTER_TABLE, Key, -1) of
+ {'EXIT', {badarg, _}} -> ets:insert(?HIT_COUNTER_TABLE, {Key, -1});
+ _ -> ok
+ end.
+
+record(Key, Value) ->
+ ets:insert(?ABSOLUTE_VALUE_COUNTER_TABLE, {Key, Value}).
+
+clear(Key) ->
+ true = ets:delete(?ABSOLUTE_VALUE_COUNTER_TABLE, Key).
+
+all() ->
+ lists:append(ets:tab2list(?HIT_COUNTER_TABLE),
+ ets:tab2list(?ABSOLUTE_VALUE_COUNTER_TABLE)).
+
+all(Type) ->
+ case Type of
+ incremental -> ets:tab2list(?HIT_COUNTER_TABLE);
+ absolute -> ets:tab2list(?ABSOLUTE_VALUE_COUNTER_TABLE)
+ end.
+
+
+% GEN_SERVER
+
+
+init(_) ->
+ ets:new(?HIT_COUNTER_TABLE, [named_table, set, public]),
+ ets:new(?ABSOLUTE_VALUE_COUNTER_TABLE, [named_table, duplicate_bag, public]),
+ {ok, #state{}}.
+
+
+handle_call(stop, _, State) ->
+ {stop, normal, stopped, State}.
+
+
+% PRIVATE API
+
+extract_value_from_ets_result(_Key, Result) ->
+ lists:map(fun({_, Value}) -> Value end, Result).
+
+
+% Unused gen_server behaviour API functions that we need to declare.
+
+%% @doc Unused
+handle_cast(foo, State) ->
+ {noreply, State}.
+
+handle_info(_Info, State) ->
+ {noreply, State}.
+
+%% @doc Unused
+terminate(_Reason, _State) -> ok.
+
+%% @doc Unused
+code_change(_OldVersion, State, _Extra) -> {ok, State}.
+
+
+%% Tests
+
+-ifdef(TEST).
+% Internal API unit tests go here
+
+
+-endif. \ No newline at end of file