You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@couchdb.apache.org by GitBox <gi...@apache.org> on 2022/10/10 17:45:26 UTC

[GitHub] [couchdb] nickva opened a new pull request, #4201: wip optimized bulk-get

nickva opened a new pull request, #4201:
URL: https://github.com/apache/couchdb/pull/4201

   Initial wip of optimized bulk_get
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998902080


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_no_quorum_on_not_found(_) ->
+    % Got a [] (not found), so wait for more workers
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    {ok, S2} = handle_message([[]], W2, S1),
+    Res2 = handle_message([[foo2(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_done_on_third(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[]], W3, S2)).
+
+t_all_different_responses(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[bar1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    Res = handle_message([[foo1(), bazNF()]], W3, S2),
+    Expect = [[foo2(), bazNF(), bar1()]],
+    ?assertEqual({stop, Expect}, Res).
+
+t_ancestors_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2()]], W2, S1),
+    ?assertEqual({stop, [[foo2()]]}, handle_message([[]], W3, S2)).
+
+t_stemmed_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo2()]], W1, S0),
+    {ok, S2} = handle_message([[foo2stemmed()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[bar1()]], W3, S2)).
+
+t_not_found_counted_as_descendant(_) ->
+    % Ancestors are merged as internal nodes correctly

Review Comment:
   Oops. This is a copy-pasta. Good find!



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] jaydoane commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
jaydoane commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r995274927


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->

Review Comment:
   Could a more descriptive name be used, perhaps something like `dedupe_responses`?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),

Review Comment:
   Are these keys (workers?) actually "dead", or just not local to NodeRef?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),

Review Comment:
   Would calling this `DedupedReqs` be more descriptive?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    % De-duplicate identical results as we go along
+    Resps1 = lists:umerge(Resps, lists:usort(NewResp)),
+    % If responses don't match or got a "not found", don't bump rcnt so we can
+    % wait for more workers.
+    NewR =
+        case {is_not_found(NewResp), length(Resps)} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, OldLen} when OldLen == length(Resps1) -> R + 1;

Review Comment:
   Does `{_, OldLen} when OldLen == length(Resps1)` always cover the prior condition too (since when `length(Resps) == 0`, then `length(Resps1)` must also be zero)?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).

Review Comment:
   Maybe add a comment here saying that we are done now because we finally got same revisions as previous messages?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    % De-duplicate identical results as we go along
+    Resps1 = lists:umerge(Resps, lists:usort(NewResp)),
+    % If responses don't match or got a "not found", don't bump rcnt so we can
+    % wait for more workers.
+    NewR =
+        case {is_not_found(NewResp), length(Resps)} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, OldLen} when OldLen == length(Resps1) -> R + 1;
+            {_, OldLen} when OldLen < length(Resps1) -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->

Review Comment:
   Would `any_not_found` be a more descriptive name?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),

Review Comment:
   `LocalWorkers`?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),

Review Comment:
   `NonLocalWorkers`?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    % De-duplicate identical results as we go along
+    Resps1 = lists:umerge(Resps, lists:usort(NewResp)),
+    % If responses don't match or got a "not found", don't bump rcnt so we can
+    % wait for more workers.
+    NewR =
+        case {is_not_found(NewResp), length(Resps)} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, OldLen} when OldLen == length(Resps1) -> R + 1;
+            {_, OldLen} when OldLen < length(Resps1) -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.

Review Comment:
   missing "for" between "already each"?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_no_quorum_on_not_found(_) ->
+    % Got a [] (not found), so wait for more workers
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    {ok, S2} = handle_message([[]], W2, S1),
+    Res2 = handle_message([[foo2(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_done_on_third(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[]], W3, S2)).
+
+t_all_different_responses(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[bar1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    Res = handle_message([[foo1(), bazNF()]], W3, S2),
+    Expect = [[foo2(), bazNF(), bar1()]],
+    ?assertEqual({stop, Expect}, Res).
+
+t_ancestors_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2()]], W2, S1),
+    ?assertEqual({stop, [[foo2()]]}, handle_message([[]], W3, S2)).
+
+t_stemmed_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo2()]], W1, S0),
+    {ok, S2} = handle_message([[foo2stemmed()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[bar1()]], W3, S2)).
+
+t_not_found_counted_as_descendant(_) ->
+    % Ancestors are merged as internal nodes correctly

Review Comment:
   Again, this comment doesn't seem to match the test name?



##########
src/fabric/test/eunit/fabric_open_revs_test.erl:
##########
@@ -0,0 +1,213 @@
+% 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(fabric_open_revs_test).
+
+-include_lib("couch/include/couch_db.hrl").
+-include_lib("couch/include/couch_eunit.hrl").
+
+open_revs_fabric_test_() ->
+    {
+        setup,
+        fun setup/0,
+        fun teardown/1,
+        with([
+            ?TDEF(t_empty_request),
+            ?TDEF(t_missing_docs),
+            ?TDEF(t_missing_docs_all),
+            ?TDEF(t_missing_docs_latest),
+            ?TDEF(t_existing_doc_missing_rev),
+            ?TDEF(t_existing_doc_missing_rev_latest),
+            ?TDEF(t_exact_rev_single_leaf),
+            ?TDEF(t_exact_rev_latest_single_leaf),
+            ?TDEF(t_exact_rev_multiple_leafs),
+            ?TDEF(t_exact_rev_latest_multiple_leafs),
+            ?TDEF(t_all_revs_latest_single_leaf),
+            ?TDEF(t_two_revs_single_doc),
+            ?TDEF(t_two_revs_single_doc_one_missing),
+            ?TDEF(t_two_revs_single_doc_latest)
+        ])
+    }.
+
+open_revs_fabric_timeout_test_() ->
+    {
+        foreach,
+        fun setup/0,
+        fun teardown/1,
+        [
+            ?TDEF_FE(t_timeout_rexi_error)
+        ]
+    }.
+
+setup() ->
+    Ctx = test_util:start_couch([fabric]),
+    DbName = ?tempdb(),
+    ok = fabric:create_db(DbName, []),
+    Docs = [
+        #doc{id = <<"a">>, revs = {1, [<<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}
+    ],
+    Opts = [?REPLICATED_CHANGES],
+    {ok, []} = fabric:update_docs(DbName, Docs, Opts),
+    {Ctx, DbName}.
+
+teardown({Ctx, _DbName}) ->

Review Comment:
   Should this delete the temp db too?



##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_no_quorum_on_not_found(_) ->
+    % Got a [] (not found), so wait for more workers
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    {ok, S2} = handle_message([[]], W2, S1),
+    Res2 = handle_message([[foo2(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_done_on_third(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[]], W3, S2)).
+
+t_all_different_responses(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[bar1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    Res = handle_message([[foo1(), bazNF()]], W3, S2),
+    Expect = [[foo2(), bazNF(), bar1()]],
+    ?assertEqual({stop, Expect}, Res).
+
+t_ancestors_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2()]], W2, S1),
+    ?assertEqual({stop, [[foo2()]]}, handle_message([[]], W3, S2)).
+
+t_stemmed_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly

Review Comment:
   Should this comment be identical to that for `t_ancestors_merge_correctly`?



##########
src/fabric/test/eunit/fabric_open_revs_test.erl:
##########
@@ -0,0 +1,213 @@
+% 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(fabric_open_revs_test).
+
+-include_lib("couch/include/couch_db.hrl").
+-include_lib("couch/include/couch_eunit.hrl").
+
+open_revs_fabric_test_() ->
+    {
+        setup,
+        fun setup/0,
+        fun teardown/1,
+        with([
+            ?TDEF(t_empty_request),
+            ?TDEF(t_missing_docs),
+            ?TDEF(t_missing_docs_all),
+            ?TDEF(t_missing_docs_latest),
+            ?TDEF(t_existing_doc_missing_rev),
+            ?TDEF(t_existing_doc_missing_rev_latest),
+            ?TDEF(t_exact_rev_single_leaf),
+            ?TDEF(t_exact_rev_latest_single_leaf),
+            ?TDEF(t_exact_rev_multiple_leafs),
+            ?TDEF(t_exact_rev_latest_multiple_leafs),
+            ?TDEF(t_all_revs_latest_single_leaf),
+            ?TDEF(t_two_revs_single_doc),
+            ?TDEF(t_two_revs_single_doc_one_missing),
+            ?TDEF(t_two_revs_single_doc_latest)
+        ])
+    }.
+
+open_revs_fabric_timeout_test_() ->
+    {
+        foreach,
+        fun setup/0,
+        fun teardown/1,
+        [
+            ?TDEF_FE(t_timeout_rexi_error)
+        ]
+    }.
+
+setup() ->
+    Ctx = test_util:start_couch([fabric]),
+    DbName = ?tempdb(),
+    ok = fabric:create_db(DbName, []),
+    Docs = [
+        #doc{id = <<"a">>, revs = {1, [<<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}
+    ],
+    Opts = [?REPLICATED_CHANGES],
+    {ok, []} = fabric:update_docs(DbName, Docs, Opts),
+    {Ctx, DbName}.
+
+teardown({Ctx, _DbName}) ->
+    meck:unload(),
+    test_util:stop_couch(Ctx).
+
+t_empty_request({_, DbName}) ->
+    ?assertEqual({ok, []}, fabric:open_revs(DbName, [], [])).
+
+t_missing_docs({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"missing">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_missing_docs_all({_, DbName}) ->
+    IdRevsOpts = {{<<"missing">>, all}, []},
+    ?assertEqual([], open_revs_single(DbName, IdRevsOpts, [])).
+
+t_missing_docs_latest({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"missing">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_existing_doc_missing_rev({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"a">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_existing_doc_missing_rev_latest({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"a">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_exact_rev_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    ResRevs = {2, [<<"x">>, <<"z">>]},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = ResRevs}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_exact_rev_latest_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    ResRevs = {2, [<<"x">>, <<"z">>]},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = ResRevs}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_exact_rev_multiple_leafs({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {1, [<<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_exact_rev_latest_multiple_leafs({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_all_revs_latest_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, all}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_two_revs_single_doc({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}, {2, <<"y">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_two_revs_single_doc_one_missing({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"y">>}, {1, <<"foo">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}},
+            {{not_found, missing}, {1, <<"foo">>}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_two_revs_single_doc_latest({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}, {2, <<"y">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_timeout_rexi_error({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    meck:new(rexi_utils, [passthrough]),
+    meck:new(rexi, [passthrough]),
+    RecFun = fun(_Refs, _KeyPos, _Fun, St, _Timeout, _PerMsgTO) ->
+        {timeout, St}
+    end,
+    meck:expect(rexi_utils, recv, RecFun),
+    ?assertEqual({error, timeout}, fabric:open_revs(DbName, [IdRevsOpts], [])),
+    % Also check that workers were cleaned up properly
+    ?assertEqual(1, meck:num_calls(rexi, kill_all, 1)).
+
+open_revs_single(DbName, IdRevsOpts, Options) ->
+    {ok, [Res]} = fabric:open_revs(DbName, [IdRevsOpts], Options),
+    % Validate batched open_revs/3 call is equivalent to calling
+    % the single open_revs/4 with that same Id and Revs args.
+    {{Id, Revs}, DocOpts} = IdRevsOpts,
+    {ok, ResSingle} = fabric:open_revs(DbName, Id, Revs, DocOpts ++ Options),
+    ?assertEqual(ResSingle, Res),

Review Comment:
   This is a very nice touch, although I'm guessing once we're convinced they are equivalent, the single version can be eliminated in favor of the more general function?



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998907307


##########
src/fabric/test/eunit/fabric_open_revs_test.erl:
##########
@@ -0,0 +1,213 @@
+% 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(fabric_open_revs_test).
+
+-include_lib("couch/include/couch_db.hrl").
+-include_lib("couch/include/couch_eunit.hrl").
+
+open_revs_fabric_test_() ->
+    {
+        setup,
+        fun setup/0,
+        fun teardown/1,
+        with([
+            ?TDEF(t_empty_request),
+            ?TDEF(t_missing_docs),
+            ?TDEF(t_missing_docs_all),
+            ?TDEF(t_missing_docs_latest),
+            ?TDEF(t_existing_doc_missing_rev),
+            ?TDEF(t_existing_doc_missing_rev_latest),
+            ?TDEF(t_exact_rev_single_leaf),
+            ?TDEF(t_exact_rev_latest_single_leaf),
+            ?TDEF(t_exact_rev_multiple_leafs),
+            ?TDEF(t_exact_rev_latest_multiple_leafs),
+            ?TDEF(t_all_revs_latest_single_leaf),
+            ?TDEF(t_two_revs_single_doc),
+            ?TDEF(t_two_revs_single_doc_one_missing),
+            ?TDEF(t_two_revs_single_doc_latest)
+        ])
+    }.
+
+open_revs_fabric_timeout_test_() ->
+    {
+        foreach,
+        fun setup/0,
+        fun teardown/1,
+        [
+            ?TDEF_FE(t_timeout_rexi_error)
+        ]
+    }.
+
+setup() ->
+    Ctx = test_util:start_couch([fabric]),
+    DbName = ?tempdb(),
+    ok = fabric:create_db(DbName, []),
+    Docs = [
+        #doc{id = <<"a">>, revs = {1, [<<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}
+    ],
+    Opts = [?REPLICATED_CHANGES],
+    {ok, []} = fabric:update_docs(DbName, Docs, Opts),
+    {Ctx, DbName}.
+
+teardown({Ctx, _DbName}) ->
+    meck:unload(),
+    test_util:stop_couch(Ctx).
+
+t_empty_request({_, DbName}) ->
+    ?assertEqual({ok, []}, fabric:open_revs(DbName, [], [])).
+
+t_missing_docs({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"missing">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_missing_docs_all({_, DbName}) ->
+    IdRevsOpts = {{<<"missing">>, all}, []},
+    ?assertEqual([], open_revs_single(DbName, IdRevsOpts, [])).
+
+t_missing_docs_latest({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"missing">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_existing_doc_missing_rev({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"a">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_existing_doc_missing_rev_latest({_, DbName}) ->
+    Rev = {1, <<"foo">>},
+    IdRevsOpts = {{<<"a">>, [Rev]}, []},
+    ?assertEqual(
+        [
+            {{not_found, missing}, Rev}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_exact_rev_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    ResRevs = {2, [<<"x">>, <<"z">>]},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = ResRevs}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_exact_rev_latest_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    ResRevs = {2, [<<"x">>, <<"z">>]},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = ResRevs}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_exact_rev_multiple_leafs({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {1, [<<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_exact_rev_latest_multiple_leafs({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_all_revs_latest_single_leaf({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, all}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_two_revs_single_doc({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}, {2, <<"y">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_two_revs_single_doc_one_missing({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"y">>}, {1, <<"foo">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}},
+            {{not_found, missing}, {1, <<"foo">>}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [])
+    ).
+
+t_two_revs_single_doc_latest({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{1, <<"z">>}, {2, <<"y">>}]}, []},
+    ?assertEqual(
+        [
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}}},
+            {ok, #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}}
+        ],
+        open_revs_single(DbName, IdRevsOpts, [latest])
+    ).
+
+t_timeout_rexi_error({_, DbName}) ->
+    IdRevsOpts = {{<<"a">>, [{2, <<"x">>}]}, []},
+    meck:new(rexi_utils, [passthrough]),
+    meck:new(rexi, [passthrough]),
+    RecFun = fun(_Refs, _KeyPos, _Fun, St, _Timeout, _PerMsgTO) ->
+        {timeout, St}
+    end,
+    meck:expect(rexi_utils, recv, RecFun),
+    ?assertEqual({error, timeout}, fabric:open_revs(DbName, [IdRevsOpts], [])),
+    % Also check that workers were cleaned up properly
+    ?assertEqual(1, meck:num_calls(rexi, kill_all, 1)).
+
+open_revs_single(DbName, IdRevsOpts, Options) ->
+    {ok, [Res]} = fabric:open_revs(DbName, [IdRevsOpts], Options),
+    % Validate batched open_revs/3 call is equivalent to calling
+    % the single open_revs/4 with that same Id and Revs args.
+    {{Id, Revs}, DocOpts} = IdRevsOpts,
+    {ok, ResSingle} = fabric:open_revs(DbName, Id, Revs, DocOpts ++ Options),
+    ?assertEqual(ResSingle, Res),

Review Comment:
   At some point they could. But since we managed to keep both implementations around we're taking advantage of it testing various corner cases both for equivalence between the old and the new API.
   
   Eventually the old version would just be re-implemented as `fabric:open_revs(Db, [{Id, Revs, DocOpts}], Options)` not unlike we already do for `update_doc` and `update_docs`



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998891109


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),

Review Comment:
   Since `reponses_fold/2` does de-duping but also other updates `Req1` could make sense there too.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998898093


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    % De-duplicate identical results as we go along
+    Resps1 = lists:umerge(Resps, lists:usort(NewResp)),
+    % If responses don't match or got a "not found", don't bump rcnt so we can
+    % wait for more workers.
+    NewR =
+        case {is_not_found(NewResp), length(Resps)} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, OldLen} when OldLen == length(Resps1) -> R + 1;

Review Comment:
   I updated this logic a bit to extract the `OldLen` and `NewLen` out of the case statement. It's a tiny bit less efficient but more clear to read.
   
   ```erlang
    case {any_not_found(NewResp), OldLen} of
               {true, _} -> R;
               {_, 0} -> R + 1;
               {_, L} when L == NewLen -> R + 1;
               {_, L} when L < NewLen -> R
           end,
   ```
   
   In this case `{_, 0}` would not be covered by` {_, L} when L == NewLen -> R + 1` as  when the first response comes `OldLen =0` but `NewLen` would be 1. So, they are different, however we do want to bump the `R` count because it's the only response we received and don't have a reason to consider that it's a diverging result.
   
   As soon as we have more than one response (`OldLen = 1`) then we switch the logic and bump the `R` count only if we start getting the same length, that is we get the same response. If we get different responses (`OldLen < NewLen`) we stop bumping it because we're hoping to get a more worker responses.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998901820


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_no_quorum_on_not_found(_) ->
+    % Got a [] (not found), so wait for more workers
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    {ok, S2} = handle_message([[]], W2, S1),
+    Res2 = handle_message([[foo2(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).
+
+t_done_on_third(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, handle_message([[]], W3, S2)).
+
+t_all_different_responses(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[bar1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2(), bar1()]], W2, S1),
+    Res = handle_message([[foo1(), bazNF()]], W3, S2),
+    Expect = [[foo2(), bazNF(), bar1()]],
+    ?assertEqual({stop, Expect}, Res).
+
+t_ancestors_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1()]], W1, S0),
+    {ok, S2} = handle_message([[foo2()]], W2, S1),
+    ?assertEqual({stop, [[foo2()]]}, handle_message([[]], W3, S2)).
+
+t_stemmed_merge_correctly(_) ->
+    % Ancestors are merged as internal nodes correctly

Review Comment:
   Yeah, it make sense there too. But I'll add a node that it include stemmed revisions too.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998887107


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),

Review Comment:
   All the workers sent to that particular node, referenced by `NodeRef` which would be just the node name like `node1@address...`, would be dead. However, there is a chance that there are still other shard copies for the same range which may still return.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998892698


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),

Review Comment:
   Or `LiveWorkers` perhaps, as we're separating some shard workers which are now known to be dead from the live ones? However since `Workers` passed in the `#st{}` record is already assumed to be the "live" / "viable" workers and we're updating those, just went with `Workers1` as in "the updated set of live workers" (which is now smaller than before).



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#issuecomment-1283371599

   > I wonder if there's a minor bug in the coverage plugin because when I look at e.g. `.eunit/fabric_open_revs_test.COVER.html` I don't actually see _any_ code that's not covered by tests.
   
   I noticed that too. The coverage was reported as 100% at some point. But then I did a minor refactoring and it switched 99% even though it still didn't show any red "missed" lines in the output. I suspect it's rounding error somewhere.
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998893554


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),

Review Comment:
   These would be dead, as in known to be on that node which we found out is dead. Sometimes it might be just one worker, but it could be a whole bunch if the node which died had multiple shard copies from multiple ranges on it.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998905773


##########
src/fabric/test/eunit/fabric_open_revs_test.erl:
##########
@@ -0,0 +1,213 @@
+% 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(fabric_open_revs_test).
+
+-include_lib("couch/include/couch_db.hrl").
+-include_lib("couch/include/couch_eunit.hrl").
+
+open_revs_fabric_test_() ->
+    {
+        setup,
+        fun setup/0,
+        fun teardown/1,
+        with([
+            ?TDEF(t_empty_request),
+            ?TDEF(t_missing_docs),
+            ?TDEF(t_missing_docs_all),
+            ?TDEF(t_missing_docs_latest),
+            ?TDEF(t_existing_doc_missing_rev),
+            ?TDEF(t_existing_doc_missing_rev_latest),
+            ?TDEF(t_exact_rev_single_leaf),
+            ?TDEF(t_exact_rev_latest_single_leaf),
+            ?TDEF(t_exact_rev_multiple_leafs),
+            ?TDEF(t_exact_rev_latest_multiple_leafs),
+            ?TDEF(t_all_revs_latest_single_leaf),
+            ?TDEF(t_two_revs_single_doc),
+            ?TDEF(t_two_revs_single_doc_one_missing),
+            ?TDEF(t_two_revs_single_doc_latest)
+        ])
+    }.
+
+open_revs_fabric_timeout_test_() ->
+    {
+        foreach,
+        fun setup/0,
+        fun teardown/1,
+        [
+            ?TDEF_FE(t_timeout_rexi_error)
+        ]
+    }.
+
+setup() ->
+    Ctx = test_util:start_couch([fabric]),
+    DbName = ?tempdb(),
+    ok = fabric:create_db(DbName, []),
+    Docs = [
+        #doc{id = <<"a">>, revs = {1, [<<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"x">>, <<"z">>]}},
+        #doc{id = <<"a">>, revs = {2, [<<"y">>, <<"z">>]}}
+    ],
+    Opts = [?REPLICATED_CHANGES],
+    {ok, []} = fabric:update_docs(DbName, Docs, Opts),
+    {Ctx, DbName}.
+
+teardown({Ctx, _DbName}) ->

Review Comment:
   Oh good find. Yes, it should!



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998888021


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    % De-duplicate identical results as we go along
+    Resps1 = lists:umerge(Resps, lists:usort(NewResp)),
+    % If responses don't match or got a "not found", don't bump rcnt so we can
+    % wait for more workers.
+    NewR =
+        case {is_not_found(NewResp), length(Resps)} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, OldLen} when OldLen == length(Resps1) -> R + 1;
+            {_, OldLen} when OldLen < length(Resps1) -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->

Review Comment:
   Agree, that's a better name.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998889559


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,455 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->

Review Comment:
   In this case it would be a more general "folding over" the responses. That's the main iteration over all the requests and updating them with the new information returned. Inside we both dedupe and also do some accounting to update the response count and worker count.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva merged pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva merged PR #4201:
URL: https://github.com/apache/couchdb/pull/4201


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [couchdb] nickva commented on a diff in pull request #4201: Implement fabric:open_revs/3

Posted by GitBox <gi...@apache.org>.
nickva commented on code in PR #4201:
URL: https://github.com/apache/couchdb/pull/4201#discussion_r998899562


##########
src/fabric/src/fabric_open_revs.erl:
##########
@@ -0,0 +1,481 @@
+% 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(fabric_open_revs).
+
+-export([
+    go/3
+]).
+
+-include_lib("mem3/include/mem3.hrl").
+-include_lib("couch/include/couch_db.hrl").
+
+-record(req, {
+    idrevs,
+    wcnt = 0,
+    rcnt = 0,
+    responses = []
+}).
+
+-record(st, {
+    r,
+    args,
+    reqs,
+    workers
+}).
+
+go(_DbName, [], _Options) ->
+    {ok, []};
+go(DbName, IdsRevsOpts, Options) ->
+    St = init_state(DbName, IdsRevsOpts, Options),
+    WShards = maps:keys(St#st.workers),
+    RexiMon = fabric_util:create_monitors(WShards),
+    try fabric_util:recv(WShards, #shard.ref, fun handle_message/3, St) of
+        {timeout, #st{workers = #{} = Workers1}} ->
+            stop_workers(Workers1),
+            fabric_util:log_timeout(maps:keys(Workers1), "open_revs"),
+            {error, timeout};
+        Else ->
+            Else
+    after
+        rexi_monitor:stop(RexiMon)
+    end.
+
+handle_message([_ | _] = Resps, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs, r = R} = St,
+    {ArgsRefs, Workers1} = maps:take(Worker, Workers),
+    ArgsResps = lists:zip(ArgsRefs, Resps),
+    Reqs1 = lists:foldl(fun responses_fold/2, Reqs, ArgsResps),
+    case not r_met(Reqs1, R) andalso have_viable_workers(Workers1) of
+        true ->
+            {ok, St#st{workers = Workers1, reqs = Reqs1}};
+        false ->
+            stop_workers(Workers1),
+            {stop, finalize(St#st.args, Reqs1)}
+    end;
+handle_message({rexi_DOWN, _, {_, NodeRef}, _}, _Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    FilterFun = fun(#shard{node = N}) -> N =:= NodeRef end,
+    DeadKeys = lists:filter(FilterFun, maps:keys(Workers)),
+    Workers1 = maps:without(DeadKeys, Workers),
+    DeadWorkers = maps:with(DeadKeys, Workers),
+    FoldFun = fun(_, ArgRefs, Acc) -> update_wcnt(Acc, ArgRefs, -1) end,
+    Reqs1 = maps:fold(FoldFun, Reqs, DeadWorkers),
+    Error = {error, {nodedown, <<"progress not possible">>}},
+    handle_error(Error, St#st{workers = Workers1, reqs = Reqs1});
+handle_message({rexi_EXIT, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message({error, Reason}, Worker, #st{} = St) ->
+    handle_message(Reason, Worker, St);
+handle_message(Reason, Worker, #st{} = St) ->
+    #st{workers = Workers, reqs = Reqs} = St,
+    {DeadArgRefs, Workers1} = maps:take(Worker, Workers),
+    Reqs1 = update_wcnt(Reqs, DeadArgRefs, -1),
+    handle_error(Reason, St#st{workers = Workers1, reqs = Reqs1}).
+
+init_state(DbName, IdsRevsOpts, Options) ->
+    DefaultR = integer_to_list(mem3:quorum(DbName)),
+    R = list_to_integer(couch_util:get_value(r, Options, DefaultR)),
+    {ArgRefs, Reqs0} = build_req_map(IdsRevsOpts),
+    ShardMap = build_worker_map(DbName, Reqs0),
+    {Workers, Reqs} = spawn_workers(Reqs0, ShardMap, Options),
+    #st{r = R, args = ArgRefs, reqs = Reqs, workers = Workers}.
+
+responses_fold({ArgRef, NewResp}, #{} = Reqs) ->
+    #{ArgRef := Req} = Reqs,
+    #req{rcnt = R, wcnt = W, responses = Resps} = Req,
+    Resps1 = merge_responses(Resps, NewResp),
+    % If responses don't match or are "not found", don't bump rcnt so we can
+    % wait for more workers.
+    OldLen = length(Resps),
+    NewLen = length(Resps1),
+    NewR =
+        case {is_not_found(NewResp), OldLen} of
+            {true, _} -> R;
+            {_, 0} -> R + 1;
+            {_, L} when L == NewLen -> R + 1;
+            {_, L} when L < NewLen -> R
+        end,
+    Reqs#{
+        ArgRef => Req#req{
+            rcnt = NewR,
+            wcnt = W - 1,
+            responses = Resps1
+        }
+    }.
+
+handle_error(Error, #st{workers = Workers, reqs = Reqs} = St) ->
+    case success_possible(Reqs) of
+        true ->
+            case have_viable_workers(Workers) of
+                true ->
+                    {ok, St};
+                false ->
+                    % Don't have a choice, have to stop
+                    {stop, finalize(St#st.args, Reqs)}
+            end;
+        false ->
+            stop_workers(Workers),
+            {error, Error}
+    end.
+
+% De-duplicate identical responses as we go along
+%
+merge_responses(Responses, Response) ->
+    Fun = fun(A, B) -> sort_key(A) =< sort_key(B) end,
+    lists:umerge(Fun, Responses, lists:usort(Fun, Response)).
+
+% Assuming docs in most cases will be identical, so check their revs and other
+% metadata and avoid checking their body, which can be quite a bit a larger,
+% just to figure they are actually the same.
+%
+sort_key({ok, #doc{id = Id, revs = Revs, deleted = Deleted}}) ->
+    {Revs, Deleted, Id};
+sort_key(NotFound) ->
+    NotFound.
+
+% Build a #{ArgRef => #req{}} map. ArgRef references the initial {{Id, Revs},
+% Opts} tuples and the #req{} is a record keeping track of response for just
+% that {Id, Revs} pair.
+%
+build_req_map(IdsRevsOpts) ->
+    Fun = fun(IdRevsOpts, Acc) ->
+        ArgRef = make_ref(),
+        {ArgRef, Acc#{ArgRef => #req{idrevs = IdRevsOpts}}}
+    end,
+    lists:mapfoldr(Fun, #{}, IdsRevsOpts).
+
+% Build a #{#shard{} => [ArgRef1, ArgRef2, ...]} map. This structure will be
+% used for launching workers and then matching up response with the original
+% args.
+%
+build_worker_map(DbName, #{} = Reqs) ->
+    FoldReqsFun = fun(ArgRef, #req{idrevs = IdRevs}, WAcc) ->
+        {{DocId, _}, _} = IdRevs,
+        FoldShardsFun = fun(Shard, WAccInner) ->
+            UpdateFun = fun(ArgRefs) -> [ArgRef | ArgRefs] end,
+            maps:update_with(Shard, UpdateFun, [ArgRef], WAccInner)
+        end,
+        lists:foldl(FoldShardsFun, WAcc, mem3:shards(DbName, DocId))
+    end,
+    maps:fold(FoldReqsFun, #{}, Reqs).
+
+spawn_workers(#{} = Reqs, #{} = ShardMap, Options) ->
+    Fun = fun(Shard, ArgRefs, {WAcc, ReqsAcc}) ->
+        Worker = rexi_cast(Shard, ArgRefs, ReqsAcc, Options),
+        WAcc1 = WAcc#{Worker => ArgRefs},
+        ReqsAcc1 = update_wcnt(ReqsAcc, ArgRefs, 1),
+        {WAcc1, ReqsAcc1}
+    end,
+    maps:fold(Fun, {#{}, Reqs}, ShardMap).
+
+% Spawn a worker and return an updated #shard{} with worker ref
+% Args are fetched from the Reqs map based on the ArgRef tag
+%
+rexi_cast(#shard{} = Shard, ArgRefs, #{} = Reqs, Options) ->
+    Fun = fun(ArgRef) when is_reference(ArgRef) ->
+        #{ArgRef := #req{idrevs = IdRevs}} = Reqs,
+        IdRevs
+    end,
+    Args = lists:map(Fun, ArgRefs),
+    RexiArgs = {fabric_rpc, open_revs, [Shard#shard.name, Args, Options]},
+    WRef = rexi:cast(Shard#shard.node, RexiArgs),
+    Shard#shard{ref = WRef}.
+
+% Update worker count for each of the #req{} records. Value may be positive
+% or negative, which could be used to decrement worker counts
+%
+update_wcnt(#{} = Reqs, ArgRefs, Val) when is_integer(Val) ->
+    Fun = fun(Ref, Acc) ->
+        #{Ref := #req{wcnt = W} = Req} = Acc,
+        Acc#{Ref => Req#req{wcnt = W + Val}}
+    end,
+    lists:foldl(Fun, Reqs, ArgRefs).
+
+% Return true if we still have any outstanding workers we could wait on
+%
+have_viable_workers(#{} = Workers) ->
+    map_size(Workers) > 0.
+
+% We can still return success if we either have some waiting workers, or at
+% least one response already each {Id, Revs} pair.
+%
+success_possible(#{} = Reqs) ->
+    Fun = fun(_, #req{wcnt = W, rcnt = R}, Acc) -> Acc andalso W + R > 0 end,
+    maps:fold(Fun, true, Reqs).
+
+r_met(#{} = Reqs, ExpectedR) ->
+    Fun = fun(_, #req{rcnt = R}, Acc) -> min(R, Acc) end,
+    maps:fold(Fun, ExpectedR, Reqs) >= ExpectedR.
+
+finalize(ArgRefs, #{} = Reqs) ->
+    Fun = fun(Ref) ->
+        #{Ref := #req{responses = Resps}} = Reqs,
+        finalize_req(Resps)
+    end,
+    lists:map(Fun, ArgRefs).
+
+finalize_req(DocRevs) ->
+    Paths = lists:map(fun rev_to_path/1, DocRevs),
+    RevTree = couch_key_tree:multi_merge([], Paths),
+    TreeLeafs = couch_key_tree:get_all_leafs(RevTree),
+    lists:map(fun path_to_reply/1, TreeLeafs).
+
+path_to_reply({?REV_MISSING, {Pos, [Rev]}}) ->
+    {{not_found, missing}, {Pos, Rev}};
+path_to_reply({#doc{} = Doc, _}) ->
+    {ok, Doc}.
+
+is_not_found([]) ->
+    true;
+is_not_found([_ | _] = Revs) ->
+    Fun = fun
+        ({{not_found, missing}, {_, _}}) -> true;
+        (_) -> false
+    end,
+    lists:any(Fun, Revs).
+
+rev_to_path({ok, #doc{} = Doc}) ->
+    couch_doc:to_path(Doc);
+rev_to_path({{not_found, missing}, {Pos, Rev}}) ->
+    {Pos, {Rev, ?REV_MISSING, []}}.
+
+stop_workers(#{} = Workers) ->
+    Fun = fun(#shard{node = Node, ref = Ref}) -> {Node, Ref} end,
+    NodeRefs = lists:map(Fun, maps:keys(Workers)),
+    rexi:kill_all(NodeRefs).
+
+-ifdef(TEST).
+-include_lib("couch/include/couch_eunit.hrl").
+
+setup_all() ->
+    config:start_link([]),
+    meck:new([fabric, couch_stats, couch_log]),
+    meck:new(rexi, [passthrough]),
+    meck:new(mem3, [passthrough]),
+    meck:new(fabric_util, [passthrough]),
+    meck:expect(fabric, update_docs, fun(_, _, _) -> {ok, nil} end),
+    meck:expect(mem3, quorum, fun(_) -> 2 end),
+    meck:expect(mem3, shards, fun(<<"db">>, <<"a">>) ->
+        [#shard{node = 'n1'}, #shard{node = 'n2'}, #shard{node = 'n3'}]
+    end),
+    meck:expect(couch_stats, increment_counter, fun(_) -> ok end),
+    meck:expect(couch_log, notice, fun(_, _) -> ok end),
+    meck:expect(rexi, cast, fun(_, _) -> make_ref() end),
+    meck:expect(rexi, kill_all, fun(_) -> ok end).
+
+teardown_all(_) ->
+    meck:unload(),
+    config:stop().
+
+setup() ->
+    meck:reset([
+        couch_log,
+        mem3,
+        rexi,
+        couch_stats,
+        fabric,
+        fabric_util
+    ]).
+
+teardown(_) ->
+    ok.
+
+st0() ->
+    IdRevsOpts = [{{<<"a">>, all}, []}],
+    init_state(<<"db">>, IdRevsOpts, []).
+
+foo1() -> {ok, #doc{revs = {1, [<<"foo">>]}}}.
+foo2() -> {ok, #doc{revs = {2, [<<"foo2">>, <<"foo">>]}}}.
+foo2stemmed() -> {ok, #doc{revs = {2, [<<"foo2">>]}}}.
+bar1() -> {ok, #doc{revs = {1, [<<"bar">>]}}}.
+bazNF() -> {{not_found, missing}, {1, <<"baz">>}}.
+baz1() -> {ok, #doc{revs = {1, [<<"baz">>]}}}.
+
+open_revs_quorum_test_() ->
+    {
+        setup,
+        fun setup_all/0,
+        fun teardown_all/1,
+        {
+            foreach,
+            fun setup/0,
+            fun teardown/1,
+            [
+                ?TDEF_FE(t_empty_request_gets_an_empty_result),
+                ?TDEF_FE(t_initial_state),
+                ?TDEF_FE(t_basic_response),
+                ?TDEF_FE(t_finish_quorum),
+                ?TDEF_FE(t_no_quorum_on_different_responses),
+                ?TDEF_FE(t_no_quorum_on_not_found),
+                ?TDEF_FE(t_done_on_third),
+                ?TDEF_FE(t_all_different_responses),
+                ?TDEF_FE(t_ancestors_merge_correctly),
+                ?TDEF_FE(t_stemmed_merge_correctly),
+                ?TDEF_FE(t_not_found_counted_as_descendant),
+                ?TDEF_FE(t_all_not_found),
+                ?TDEF_FE(t_rev_not_found_returned),
+                ?TDEF_FE(t_rexi_errors_progress),
+                ?TDEF_FE(t_generic_errors_progress),
+                ?TDEF_FE(t_failure_on_all_errors)
+            ]
+        }
+    }.
+
+t_empty_request_gets_an_empty_result(_) ->
+    ?assertEqual({ok, []}, go(<<"foo">>, [], [])).
+
+t_initial_state(_) ->
+    % Smoke test that we have setup our state correctly
+    S0 = st0(),
+    ?assertMatch(#st{args = [_], r = 2, reqs = #{}, workers = #{}}, S0),
+    #st{args = ArgsRefs, reqs = Reqs, workers = Workers} = S0,
+    % The args refs list is the reqs keys
+    ?assertEqual(lists:sort(ArgsRefs), lists:sort(maps:keys(Reqs))),
+    % Each worker's args is from the args refs list and there are no args which
+    % which haven't been assigned to at least one worker.
+    SpawnedArgs = lists:flatten(maps:values(Workers)),
+    ?assertEqual(lists:sort(ArgsRefs), lists:usort(SpawnedArgs)),
+    maps:map(
+        fun(_, #req{} = Req) ->
+            % 3 workers were spawned
+            ?assertEqual(3, Req#req.wcnt),
+            % no workers have returned yet
+            ?assertEqual(0, Req#req.rcnt),
+            % responses is an empty list (since no workers returned yet)
+            ?assertEqual([], Req#req.responses)
+        end,
+        Reqs
+    ).
+
+t_basic_response(_) ->
+    S0 = #st{workers = Workers0} = st0(),
+    [W1 | _] = lists:sort(maps:keys(Workers0)),
+    Res = handle_message([[foo1(), bar1()]], W1, S0),
+    ?assertMatch({ok, #st{}}, Res),
+    {ok, #st{reqs = Reqs, workers = Workers1}} = Res,
+    ?assertEqual(2, map_size(Workers1)),
+    ?assertNot(maps:is_key(W1, Workers1)),
+    ?assertEqual(1, map_size(Reqs)),
+    [#req{wcnt = W, rcnt = R}] = maps:values(Reqs),
+    ?assertEqual(2, W),
+    ?assertEqual(1, R).
+
+t_finish_quorum(_) ->
+    % Two messages with the same revisions means we're done
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2 | _] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res = handle_message([[bar1(), foo1()]], W2, S1),
+    ?assertEqual({stop, [[foo1(), bar1()]]}, Res).
+
+t_no_quorum_on_different_responses(_) ->
+    % Got different revisions, so we're waiting for more workers.
+    S0 = #st{workers = Workers0} = st0(),
+    [W1, W2, W3] = lists:sort(maps:keys(Workers0)),
+    {ok, S1} = handle_message([[foo1(), bar1()]], W1, S0),
+    Res1 = handle_message([[foo2(), bar1()]], W2, S1),
+    ?assertMatch({ok, #st{}}, Res1),
+    {ok, S2} = Res1,
+    Res2 = handle_message([[foo1(), bar1()]], W3, S2),
+    ?assertEqual({stop, [[foo2(), bar1()]]}, Res2).

Review Comment:
   Good idea, I'll add a comment about the stopping condition.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@couchdb.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org