summaryrefslogtreecommitdiff
diff options
context:
space:
mode:
authorRobert Newson <robert.newson@cloudant.com>2012-06-18 19:38:09 +0100
committerRobert Newson <robert.newson@cloudant.com>2012-06-18 19:38:09 +0100
commit95732bf56606847c6a2a1d1d38703a6e8b688429 (patch)
treeebd35d3cbdecca97c7fda96c732577ffba888529
parent0250151979a0746b5f97af15e2ef36f679c0d562 (diff)
Fix _replicator db
-rw-r--r--apps/couch/src/couch_rep.erl8
-rw-r--r--apps/couch/src/couch_replication_manager.erl629
-rw-r--r--rel/overlay/etc/default.ini1
-rw-r--r--rel/reltool.config3
4 files changed, 6 insertions, 635 deletions
diff --git a/apps/couch/src/couch_rep.erl b/apps/couch/src/couch_rep.erl
index c7d09283..74ed95d0 100644
--- a/apps/couch/src/couch_rep.erl
+++ b/apps/couch/src/couch_rep.erl
@@ -176,7 +176,7 @@ do_init([{BaseId, _Ext} = RepId, {PostProps}, UserCtx] = InitArgs) ->
couch_task_status:add_task("Replication", io_lib:format("~s: ~s -> ~s",
[ShortId, dbname(Source), dbname(Target)]), "Starting"),
- couch_replication_manager:replication_started(RepId),
+ couch_replicator_manager:replication_started(RepId),
State = #state{
changes_feed = ChangesFeed,
@@ -273,12 +273,12 @@ handle_info({'EXIT', _Pid, Reason}, State) ->
terminate(normal, #state{checkpoint_scheduled=nil, init_args=[RepId | _]} = State) ->
do_terminate(State),
- couch_replication_manager:replication_completed(RepId);
+ couch_replicator_manager:replication_completed(RepId);
terminate(normal, #state{init_args=[RepId | _]} = State) ->
timer:cancel(State#state.checkpoint_scheduled),
do_terminate(do_checkpoint(State)),
- couch_replication_manager:replication_completed(RepId);
+ couch_replicator_manager:replication_completed(RepId);
terminate(shutdown, #state{listeners = Listeners} = State) ->
% continuous replication stopped
@@ -288,7 +288,7 @@ terminate(shutdown, #state{listeners = Listeners} = State) ->
terminate(Reason, #state{listeners = Listeners, init_args=[RepId | _]} = State) ->
[gen_server:reply(L, {error, Reason}) || L <- Listeners],
terminate_cleanup(State),
- couch_replication_manager:replication_error(RepId, Reason).
+ couch_replicator_manager:replication_error(RepId, Reason).
code_change(_OldVsn, State, _Extra) ->
{ok, State}.
diff --git a/apps/couch/src/couch_replication_manager.erl b/apps/couch/src/couch_replication_manager.erl
deleted file mode 100644
index 6ced17e4..00000000
--- a/apps/couch/src/couch_replication_manager.erl
+++ /dev/null
@@ -1,629 +0,0 @@
-% 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_replication_manager).
--behaviour(gen_server).
-
-% public API
--export([replication_started/1, replication_completed/1, replication_error/2]).
-
-% gen_server callbacks
--export([start_link/0, init/1, handle_call/3, handle_info/2, handle_cast/2]).
--export([code_change/3, terminate/2]).
-
--include("couch_db.hrl").
--include("couch_js_functions.hrl").
-
--define(DOC_TO_REP, couch_rep_doc_id_to_rep_id).
--define(REP_TO_STATE, couch_rep_id_to_rep_state).
--define(INITIAL_WAIT, 2.5). % seconds
--define(MAX_WAIT, 600). % seconds
-
--record(state, {
- changes_feed_loop = nil,
- db_notifier = nil,
- rep_db_name = nil,
- rep_start_pids = [],
- max_retries
-}).
-
--record(rep_state, {
- doc_id,
- user_ctx,
- doc,
- starting,
- retries_left,
- max_retries,
- wait = ?INITIAL_WAIT
-}).
-
--import(couch_util, [
- get_value/2,
- get_value/3,
- to_binary/1
-]).
-
-
-start_link() ->
- gen_server:start_link({local, ?MODULE}, ?MODULE, [], []).
-
-
-replication_started({BaseId, _} = RepId) ->
- case rep_state(RepId) of
- nil ->
- ok;
- #rep_state{doc_id = DocId} ->
- update_rep_doc(DocId, [
- {<<"_replication_state">>, <<"triggered">>},
- {<<"_replication_id">>, ?l2b(BaseId)}]),
- ok = gen_server:call(?MODULE, {rep_started, RepId}, infinity),
- ?LOG_INFO("Document `~s` triggered replication `~s`",
- [DocId, pp_rep_id(RepId)])
- end.
-
-
-replication_completed(RepId) ->
- case rep_state(RepId) of
- nil ->
- ok;
- #rep_state{doc_id = DocId} ->
- update_rep_doc(DocId, [{<<"_replication_state">>, <<"completed">>}]),
- ok = gen_server:call(?MODULE, {rep_complete, RepId}, infinity),
- ?LOG_INFO("Replication `~s` finished (triggered by document `~s`)",
- [pp_rep_id(RepId), DocId])
- end.
-
-
-replication_error({BaseId, _} = RepId, Error) ->
- case rep_state(RepId) of
- nil ->
- ok;
- #rep_state{doc_id = DocId} ->
- % TODO: maybe add error reason to replication document
- update_rep_doc(DocId, [
- {<<"_replication_state">>, <<"error">>},
- {<<"_replication_id">>, ?l2b(BaseId)}]),
- ok = gen_server:call(?MODULE, {rep_error, RepId, Error}, infinity)
- end.
-
-
-init(_) ->
- process_flag(trap_exit, true),
- ?DOC_TO_REP = ets:new(?DOC_TO_REP, [named_table, set, protected]),
- ?REP_TO_STATE = ets:new(?REP_TO_STATE, [named_table, set, protected]),
- Server = self(),
- ok = couch_config:register(
- fun("replicator", "db", NewName) ->
- ok = gen_server:cast(Server, {rep_db_changed, ?l2b(NewName)});
- ("replicator", "max_replication_retry_count", V) ->
- ok = gen_server:cast(Server, {set_max_retries, retries_value(V)})
- end
- ),
- {Loop, RepDbName} = changes_feed_loop(),
- {ok, #state{
- changes_feed_loop = Loop,
- rep_db_name = RepDbName,
- db_notifier = db_update_notifier(),
- max_retries = retries_value(
- couch_config:get("replicator", "max_replication_retry_count", "10"))
- }}.
-
-
-handle_call({rep_db_update, {ChangeProps} = Change}, _From, State) ->
- NewState = try
- process_update(State, Change)
- catch
- _Tag:Error ->
- {RepProps} = get_value(doc, ChangeProps),
- DocId = get_value(<<"_id">>, RepProps),
- rep_db_update_error(Error, DocId),
- State
- end,
- {reply, ok, NewState};
-
-handle_call({rep_started, RepId}, _From, State) ->
- case rep_state(RepId) of
- nil ->
- ok;
- RepState ->
- NewRepState = RepState#rep_state{
- starting = false,
- retries_left = State#state.max_retries,
- max_retries = State#state.max_retries,
- wait = ?INITIAL_WAIT
- },
- true = ets:insert(?REP_TO_STATE, {RepId, NewRepState})
- end,
- {reply, ok, State};
-
-handle_call({rep_complete, RepId}, _From, State) ->
- true = ets:delete(?REP_TO_STATE, RepId),
- {reply, ok, State};
-
-handle_call({rep_error, RepId, Error}, _From, State) ->
- {reply, ok, replication_error(State, RepId, Error)};
-
-handle_call(Msg, From, State) ->
- ?LOG_ERROR("Replication manager received unexpected call ~p from ~p",
- [Msg, From]),
- {stop, {error, {unexpected_call, Msg}}, State}.
-
-
-handle_cast({rep_db_changed, NewName}, #state{rep_db_name = NewName} = State) ->
- {noreply, State};
-
-handle_cast({rep_db_changed, _NewName}, State) ->
- {noreply, restart(State)};
-
-handle_cast({rep_db_created, NewName}, #state{rep_db_name = NewName} = State) ->
- {noreply, State};
-
-handle_cast({rep_db_created, _NewName}, State) ->
- {noreply, restart(State)};
-
-handle_cast({set_max_retries, MaxRetries}, State) ->
- {noreply, State#state{max_retries = MaxRetries}};
-
-handle_cast(Msg, State) ->
- ?LOG_ERROR("Replication manager received unexpected cast ~p", [Msg]),
- {stop, {error, {unexpected_cast, Msg}}, State}.
-
-
-handle_info({'EXIT', From, normal}, #state{changes_feed_loop = From} = State) ->
- % replicator DB deleted
- {noreply, State#state{changes_feed_loop = nil, rep_db_name = nil}};
-
-handle_info({'EXIT', From, Reason}, #state{db_notifier = From} = State) ->
- ?LOG_ERROR("Database update notifier died. Reason: ~p", [Reason]),
- {stop, {db_update_notifier_died, Reason}, State};
-
-handle_info({'EXIT', From, normal}, #state{rep_start_pids = Pids} = State) ->
- % one of the replication start processes terminated successfully
- {noreply, State#state{rep_start_pids = Pids -- [From]}};
-
-handle_info({'DOWN', _Ref, _, _, _}, State) ->
- % From a db monitor created by a replication process. Ignore.
- {noreply, State};
-
-handle_info(Msg, State) ->
- ?LOG_ERROR("Replication manager received unexpected message ~p", [Msg]),
- {stop, {unexpected_msg, Msg}, State}.
-
-
-terminate(_Reason, State) ->
- #state{
- rep_start_pids = StartPids,
- changes_feed_loop = Loop,
- db_notifier = Notifier
- } = State,
- stop_all_replications(),
- lists:foreach(
- fun(Pid) ->
- catch unlink(Pid),
- catch exit(Pid, stop)
- end,
- [Loop | StartPids]),
- true = ets:delete(?REP_TO_STATE),
- true = ets:delete(?DOC_TO_REP),
- couch_db_update_notifier:stop(Notifier).
-
-
-code_change(_OldVsn, State, _Extra) ->
- {ok, State}.
-
-
-changes_feed_loop() ->
- {ok, RepDb} = ensure_rep_db_exists(),
- Server = self(),
- Pid = spawn_link(
- fun() ->
- ChangesFeedFun = couch_changes:handle_changes(
- #changes_args{
- include_docs = true,
- feed = "continuous",
- timeout = infinity,
- db_open_options = [sys_db]
- },
- {json_req, null},
- RepDb
- ),
- ChangesFeedFun(
- fun({change, Change, _}, _) ->
- case has_valid_rep_id(Change) of
- true ->
- ok = gen_server:call(
- Server, {rep_db_update, Change}, infinity);
- false ->
- ok
- end;
- (_, _) ->
- ok
- end
- )
- end
- ),
- couch_db:close(RepDb),
- {Pid, couch_db:name(RepDb)}.
-
-
-has_valid_rep_id({Change}) ->
- has_valid_rep_id(get_value(<<"id">>, Change));
-has_valid_rep_id(<<?DESIGN_DOC_PREFIX, _Rest/binary>>) ->
- false;
-has_valid_rep_id(_Else) ->
- true.
-
-
-db_update_notifier() ->
- Server = self(),
- {ok, Notifier} = couch_db_update_notifier:start_link(
- fun({created, DbName}) ->
- case ?l2b(couch_config:get("replicator", "db", "_replicator")) of
- DbName ->
- ok = gen_server:cast(Server, {rep_db_created, DbName});
- _ ->
- ok
- end;
- (_) ->
- % no need to handle the 'deleted' event - the changes feed loop
- % dies when the database is deleted
- ok
- end
- ),
- Notifier.
-
-
-restart(#state{changes_feed_loop = Loop, rep_start_pids = StartPids} = State) ->
- stop_all_replications(),
- lists:foreach(
- fun(Pid) ->
- catch unlink(Pid),
- catch exit(Pid, rep_db_changed)
- end,
- [Loop | StartPids]),
- {NewLoop, NewRepDbName} = changes_feed_loop(),
- State#state{
- changes_feed_loop = NewLoop,
- rep_db_name = NewRepDbName,
- rep_start_pids = []
- }.
-
-
-process_update(State, {Change}) ->
- {RepProps} = JsonRepDoc = get_value(doc, Change),
- DocId = get_value(<<"_id">>, RepProps),
- case get_value(<<"deleted">>, Change, false) of
- true ->
- rep_doc_deleted(DocId),
- State;
- false ->
- case get_value(<<"_replication_state">>, RepProps) of
- undefined ->
- maybe_start_replication(State, DocId, JsonRepDoc);
- <<"triggered">> ->
- maybe_start_replication(State, DocId, JsonRepDoc);
- <<"completed">> ->
- replication_complete(DocId),
- State;
- <<"error">> ->
- case ets:lookup(?DOC_TO_REP, DocId) of
- [] ->
- maybe_start_replication(State, DocId, JsonRepDoc);
- _ ->
- State
- end
- end
- end.
-
-
-rep_db_update_error(Error, DocId) ->
- case Error of
- {bad_rep_doc, Reason} ->
- ok;
- _ ->
- Reason = to_binary(Error)
- end,
- ?LOG_ERROR("Replication manager, error processing document `~s`: ~s",
- [DocId, Reason]),
- update_rep_doc(DocId, [{<<"_replication_state">>, <<"error">>}]).
-
-
-rep_user_ctx({RepDoc}) ->
- case get_value(<<"user_ctx">>, RepDoc) of
- undefined ->
- #user_ctx{};
- {UserCtx} ->
- #user_ctx{
- name = get_value(<<"name">>, UserCtx, null),
- roles = get_value(<<"roles">>, UserCtx, [])
- }
- end.
-
-
-maybe_start_replication(State, DocId, RepDoc) ->
- UserCtx = rep_user_ctx(RepDoc),
- {BaseId, _} = RepId = make_rep_id(RepDoc, UserCtx),
- case rep_state(RepId) of
- nil ->
- RepState = #rep_state{
- doc_id = DocId,
- user_ctx = UserCtx,
- doc = RepDoc,
- starting = true,
- retries_left = State#state.max_retries,
- max_retries = State#state.max_retries
- },
- true = ets:insert(?REP_TO_STATE, {RepId, RepState}),
- true = ets:insert(?DOC_TO_REP, {DocId, RepId}),
- ?LOG_INFO("Attempting to start replication `~s` (document `~s`).",
- [pp_rep_id(RepId), DocId]),
- Server = self(),
- Pid = spawn_link(fun() ->
- start_replication(Server, RepDoc, RepId, UserCtx, 0)
- end),
- State#state{rep_start_pids = [Pid | State#state.rep_start_pids]};
- #rep_state{doc_id = DocId} ->
- State;
- #rep_state{starting = false, doc_id = OtherDocId} ->
- ?LOG_INFO("The replication specified by the document `~s` was already"
- " triggered by the document `~s`", [DocId, OtherDocId]),
- maybe_tag_rep_doc(DocId, RepDoc, ?l2b(BaseId)),
- State;
- #rep_state{starting = true, doc_id = OtherDocId} ->
- ?LOG_INFO("The replication specified by the document `~s` is already"
- " being triggered by the document `~s`", [DocId, OtherDocId]),
- maybe_tag_rep_doc(DocId, RepDoc, ?l2b(BaseId)),
- State
- end.
-
-
-make_rep_id(RepDoc, UserCtx) ->
- try
- couch_rep:make_replication_id(RepDoc, UserCtx)
- catch
- throw:{error, Reason} ->
- throw({bad_rep_doc, Reason});
- Tag:Err ->
- throw({bad_rep_doc, to_binary({Tag, Err})})
- end.
-
-
-maybe_tag_rep_doc(DocId, {RepProps}, RepId) ->
- case get_value(<<"_replication_id">>, RepProps) of
- RepId ->
- ok;
- _ ->
- update_rep_doc(DocId, [{<<"_replication_id">>, RepId}])
- end.
-
-
-start_replication(Server, RepDoc, RepId, UserCtx, Wait) ->
- ok = timer:sleep(Wait * 1000),
- case (catch couch_rep:start_replication(RepDoc, RepId, UserCtx)) of
- Pid when is_pid(Pid) ->
- ok = gen_server:call(Server, {rep_started, RepId}, infinity),
- couch_rep:get_result(Pid, RepId, RepDoc, UserCtx);
- Error ->
- replication_error(RepId, Error)
- end.
-
-
-replication_complete(DocId) ->
- case ets:lookup(?DOC_TO_REP, DocId) of
- [{DocId, RepId}] ->
- case rep_state(RepId) of
- nil ->
- couch_rep:end_replication(RepId);
- #rep_state{} ->
- ok
- end,
- true = ets:delete(?DOC_TO_REP, DocId);
- _ ->
- ok
- end.
-
-
-rep_doc_deleted(DocId) ->
- case ets:lookup(?DOC_TO_REP, DocId) of
- [{DocId, RepId}] ->
- couch_rep:end_replication(RepId),
- true = ets:delete(?REP_TO_STATE, RepId),
- true = ets:delete(?DOC_TO_REP, DocId),
- ?LOG_INFO("Stopped replication `~s` because replication document `~s`"
- " was deleted", [pp_rep_id(RepId), DocId]);
- [] ->
- ok
- end.
-
-
-replication_error(State, RepId, Error) ->
- case rep_state(RepId) of
- nil ->
- State;
- RepState ->
- maybe_retry_replication(RepId, RepState, Error, State)
- end.
-
-maybe_retry_replication(RepId, #rep_state{retries_left = 0} = RepState, Error, State) ->
- #rep_state{
- doc_id = DocId,
- max_retries = MaxRetries
- } = RepState,
- couch_rep:end_replication(RepId),
- true = ets:delete(?REP_TO_STATE, RepId),
- true = ets:delete(?DOC_TO_REP, DocId),
- ?LOG_ERROR("Error in replication `~s` (triggered by document `~s`): ~s"
- "~nReached maximum retry attempts (~p).",
- [pp_rep_id(RepId), DocId, to_binary(error_reason(Error)), MaxRetries]),
- State;
-
-maybe_retry_replication(RepId, RepState, Error, State) ->
- #rep_state{
- doc_id = DocId,
- user_ctx = UserCtx,
- doc = RepDoc
- } = RepState,
- #rep_state{wait = Wait} = NewRepState = state_after_error(RepState),
- true = ets:insert(?REP_TO_STATE, {RepId, NewRepState}),
- ?LOG_ERROR("Error in replication `~s` (triggered by document `~s`): ~s"
- "~nRestarting replication in ~p seconds.",
- [pp_rep_id(RepId), DocId, to_binary(error_reason(Error)), Wait]),
- Server = self(),
- Pid = spawn_link(fun() ->
- start_replication(Server, RepDoc, RepId, UserCtx, Wait)
- end),
- State#state{rep_start_pids = [Pid | State#state.rep_start_pids]}.
-
-
-stop_all_replications() ->
- ?LOG_INFO("Stopping all ongoing replications because the replicator"
- " database was deleted or changed", []),
- ets:foldl(
- fun({_, RepId}, _) ->
- couch_rep:end_replication(RepId)
- end,
- ok, ?DOC_TO_REP),
- true = ets:delete_all_objects(?REP_TO_STATE),
- true = ets:delete_all_objects(?DOC_TO_REP).
-
-
-update_rep_doc(RepDocId, KVs) ->
- {ok, RepDb} = ensure_rep_db_exists(),
- try
- case couch_db:open_doc(RepDb, RepDocId, []) of
- {ok, LatestRepDoc} ->
- update_rep_doc(RepDb, LatestRepDoc, KVs);
- _ ->
- ok
- end
- catch throw:conflict ->
- % Shouldn't happen, as by default only the role _replicator can
- % update replication documents.
- ?LOG_ERROR("Conflict error when updating replication document `~s`."
- " Retrying.", [RepDocId]),
- ok = timer:sleep(5),
- update_rep_doc(RepDocId, KVs)
- after
- couch_db:close(RepDb)
- end.
-
-update_rep_doc(RepDb, #doc{body = {RepDocBody}} = RepDoc, KVs) ->
- NewRepDocBody = lists:foldl(
- fun({<<"_replication_state">> = K, State} = KV, Body) ->
- case get_value(K, Body) of
- State ->
- Body;
- _ ->
- Body1 = lists:keystore(K, 1, Body, KV),
- lists:keystore(
- <<"_replication_state_time">>, 1, Body1,
- {<<"_replication_state_time">>, timestamp()})
- end;
- ({K, _V} = KV, Body) ->
- lists:keystore(K, 1, Body, KV)
- end,
- RepDocBody, KVs),
- case NewRepDocBody of
- RepDocBody ->
- ok;
- _ ->
- % Might not succeed - when the replication doc is deleted right
- % before this update (not an error, ignore).
- couch_db:update_doc(RepDb, RepDoc#doc{body = {NewRepDocBody}}, [])
- end.
-
-
-% RFC3339 timestamps.
-% Note: doesn't include the time seconds fraction (RFC3339 says it's optional).
-timestamp() ->
- {{Year, Month, Day}, {Hour, Min, Sec}} = calendar:now_to_local_time(now()),
- UTime = erlang:universaltime(),
- LocalTime = calendar:universal_time_to_local_time(UTime),
- DiffSecs = calendar:datetime_to_gregorian_seconds(LocalTime) -
- calendar:datetime_to_gregorian_seconds(UTime),
- zone(DiffSecs div 3600, (DiffSecs rem 3600) div 60),
- iolist_to_binary(
- io_lib:format("~4..0w-~2..0w-~2..0wT~2..0w:~2..0w:~2..0w~s",
- [Year, Month, Day, Hour, Min, Sec,
- zone(DiffSecs div 3600, (DiffSecs rem 3600) div 60)])).
-
-zone(Hr, Min) when Hr >= 0, Min >= 0 ->
- io_lib:format("+~2..0w:~2..0w", [Hr, Min]);
-zone(Hr, Min) ->
- io_lib:format("-~2..0w:~2..0w", [abs(Hr), abs(Min)]).
-
-
-ensure_rep_db_exists() ->
- DbName = ?l2b(couch_config:get("replicator", "db", "_replicator")),
- Opts = [
- {user_ctx, #user_ctx{roles=[<<"_admin">>, <<"_replicator">>]}},
- sys_db
- ],
- case couch_db:open(DbName, Opts) of
- {ok, Db} ->
- Db;
- _Error ->
- {ok, Db} = couch_db:create(DbName, Opts)
- end,
- ok = ensure_rep_ddoc_exists(Db, <<"_design/_replicator">>),
- {ok, Db}.
-
-
-ensure_rep_ddoc_exists(RepDb, DDocID) ->
- case couch_db:open_doc(RepDb, DDocID, []) of
- {ok, _Doc} ->
- ok;
- _ ->
- DDoc = couch_doc:from_json_obj({[
- {<<"_id">>, DDocID},
- {<<"language">>, <<"javascript">>},
- {<<"validate_doc_update">>, ?REP_DB_DOC_VALIDATE_FUN}
- ]}),
- {ok, _Rev} = couch_db:update_doc(RepDb, DDoc, [])
- end,
- ok.
-
-
-% pretty-print replication id
-pp_rep_id({Base, Extension}) ->
- Base ++ Extension.
-
-
-rep_state(RepId) ->
- case ets:lookup(?REP_TO_STATE, RepId) of
- [{RepId, RepState}] ->
- RepState;
- [] ->
- nil
- end.
-
-
-error_reason({error, Reason}) ->
- Reason;
-error_reason(Reason) ->
- Reason.
-
-
-retries_value("infinity") ->
- infinity;
-retries_value(Value) ->
- list_to_integer(Value).
-
-
-state_after_error(#rep_state{retries_left = Left, wait = Wait} = State) ->
- Wait2 = erlang:min(trunc(Wait * 2), ?MAX_WAIT),
- case Left of
- infinity ->
- State#rep_state{wait = Wait2};
- _ ->
- State#rep_state{retries_left = Left - 1, wait = Wait2}
- end.
diff --git a/rel/overlay/etc/default.ini b/rel/overlay/etc/default.ini
index fdd11e14..af950a7b 100644
--- a/rel/overlay/etc/default.ini
+++ b/rel/overlay/etc/default.ini
@@ -84,7 +84,6 @@ stats_aggregator={couch_stats_aggregator, start, []}
stats_collector={couch_stats_collector, start, []}
uuids={couch_uuids, start, []}
auth_cache={couch_auth_cache, start_link, []}
-replication_manager={couch_replication_manager, start_link, []}
vhosts={couch_httpd_vhost, start_link, []}
os_daemons={couch_os_daemons, start_link, []}
; Uncomment next line to enable SSL daemon
diff --git a/rel/reltool.config b/rel/reltool.config
index 4486c1d5..9fd5699d 100644
--- a/rel/reltool.config
+++ b/rel/reltool.config
@@ -31,7 +31,8 @@
rexi,
fabric,
mem3,
- chttpd
+ chttpd,
+ couch_replicator
]},
{rel, "start_clean", "", [kernel, stdlib]},
{boot_rel, "bigcouch"},