You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@couchdb.apache.org by va...@apache.org on 2021/08/26 20:23:28 UTC

[couchdb] branch remove-unused-attachment-module created (now 0a212ae)

This is an automated email from the ASF dual-hosted git repository.

vatamane pushed a change to branch remove-unused-attachment-module
in repository https://gitbox.apache.org/repos/asf/couchdb.git.


      at 0a212ae  Remove unused fabric_doc_attachments

This branch includes the following new commits:

     new 0a212ae  Remove unused fabric_doc_attachments

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


[couchdb] 01/01: Remove unused fabric_doc_attachments

Posted by va...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

vatamane pushed a commit to branch remove-unused-attachment-module
in repository https://gitbox.apache.org/repos/asf/couchdb.git

commit 0a212aee95dcff2674fa911301ccc762d601c279
Author: Nick Vatamaniuc <va...@gmail.com>
AuthorDate: Thu Aug 26 16:10:16 2021 -0400

    Remove unused fabric_doc_attachments
    
    This module was kept around since 2.2.0 only to facilitate cluster upgrades
    after we switched the receiver logic to not closures around between nodes
    https://github.com/apache/couchdb/commit/fe53e437ca5ec9d23aa1b55d7934daced157a9e3
---
 src/fabric/src/fabric_doc_attachments.erl | 160 ------------------------------
 1 file changed, 160 deletions(-)

diff --git a/src/fabric/src/fabric_doc_attachments.erl b/src/fabric/src/fabric_doc_attachments.erl
deleted file mode 100644
index 922a89e..0000000
--- a/src/fabric/src/fabric_doc_attachments.erl
+++ /dev/null
@@ -1,160 +0,0 @@
-% Licensed under the Apache License, Version 2.0 (the "License"); you may not
-% use this file except in compliance with the License. You may obtain a copy of
-% the License at
-%
-%   http://www.apache.org/licenses/LICENSE-2.0
-%
-% Unless required by applicable law or agreed to in writing, software
-% distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-% WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
-% License for the specific language governing permissions and limitations under
-% the License.
-
--module(fabric_doc_attachments).
-
--compile(tuple_calls).
-
--include_lib("fabric/include/fabric.hrl").
--include_lib("couch/include/couch_db.hrl").
-
-%% couch api calls
--export([receiver/2]).
-
-receiver(_Req, undefined) ->
-    <<"">>;
-receiver(_Req, {unknown_transfer_encoding, Unknown}) ->
-    exit({unknown_transfer_encoding, Unknown});
-receiver(Req, chunked) ->
-    MiddleMan = spawn(fun() -> middleman(Req, chunked) end),
-    fun(4096, ChunkFun, State) ->
-        write_chunks(MiddleMan, ChunkFun, State)
-    end;
-receiver(_Req, 0) ->
-    <<"">>;
-receiver(Req, Length) when is_integer(Length) ->
-    maybe_send_continue(Req),
-    Middleman = spawn(fun() -> middleman(Req, Length) end),
-    fun() ->
-        Middleman ! {self(), gimme_data},
-        Timeout = fabric_util:attachments_timeout(),
-        receive
-            {Middleman, Data} ->
-                rexi:reply(attachment_chunk_received),
-                Data
-        after Timeout ->
-            exit(timeout)
-        end
-    end;
-receiver(_Req, Length) ->
-    exit({length_not_integer, Length}).
-
-%%
-%% internal
-%%
-
-maybe_send_continue(#httpd{mochi_req = MochiReq} = Req) ->
-    case couch_httpd:header_value(Req, "expect") of
-    undefined ->
-        ok;
-    Expect ->
-        case string:to_lower(Expect) of
-        "100-continue" ->
-            MochiReq:start_raw_response({100, gb_trees:empty()});
-        _ ->
-            ok
-        end
-    end.
-
-write_chunks(MiddleMan, ChunkFun, State) ->
-    MiddleMan ! {self(), gimme_data},
-    Timeout = fabric_util:attachments_timeout(),
-    receive
-    {MiddleMan, ChunkRecordList} ->
-        rexi:reply(attachment_chunk_received),
-        case flush_chunks(ChunkRecordList, ChunkFun, State) of
-            {continue, NewState} ->
-                write_chunks(MiddleMan, ChunkFun, NewState);
-            {done, NewState} ->
-                NewState
-        end
-    after Timeout ->
-        exit(timeout)
-    end.
-
-flush_chunks([], _ChunkFun, State) ->
-    {continue, State};
-flush_chunks([{0, _}], _ChunkFun, State) ->
-    {done, State};
-flush_chunks([Chunk | Rest], ChunkFun, State) ->
-    NewState = ChunkFun(Chunk, State),
-    flush_chunks(Rest, ChunkFun, NewState).
-
-receive_unchunked_attachment(_Req, 0) ->
-    ok;
-receive_unchunked_attachment(Req, Length) ->
-    receive {MiddleMan, go} ->
-        Data = couch_httpd:recv(Req, 0),
-        MiddleMan ! {self(), Data}
-    end,
-    receive_unchunked_attachment(Req, Length - size(Data)).
-
-middleman(Req, chunked) ->
-    % spawn a process to actually receive the uploaded data
-    RcvFun = fun(ChunkRecord, ok) ->
-        receive {From, go} -> From ! {self(), ChunkRecord} end, ok
-    end,
-    Receiver = spawn(fun() -> couch_httpd:recv_chunked(Req,4096,RcvFun,ok) end),
-
-    % take requests from the DB writers and get data from the receiver
-    N = config:get_integer("cluster", "n", 3),
-    Timeout = fabric_util:attachments_timeout(),
-    middleman_loop(Receiver, N, [], [], Timeout);
-
-middleman(Req, Length) ->
-    Receiver = spawn(fun() -> receive_unchunked_attachment(Req, Length) end),
-    N = config:get_integer("cluster", "n", 3),
-    Timeout = fabric_util:attachments_timeout(),
-    middleman_loop(Receiver, N, [], [], Timeout).
-
-middleman_loop(Receiver, N, Counters0, ChunkList0, Timeout) ->
-    receive {From, gimme_data} ->
-        % Figure out how far along this writer (From) is in the list
-        ListIndex = case fabric_dict:lookup_element(From, Counters0) of
-        undefined -> 0;
-        I -> I
-        end,
-
-        % Talk to the receiver to get another chunk if necessary
-        ChunkList1 = if ListIndex == length(ChunkList0) ->
-            Receiver ! {self(), go},
-            receive
-                {Receiver, ChunkRecord} ->
-                    ChunkList0 ++ [ChunkRecord]
-            end;
-        true -> ChunkList0 end,
-
-        % reply to the writer
-        Reply = lists:nthtail(ListIndex, ChunkList1),
-        From ! {self(), Reply},
-
-        % Update the counter for this writer
-        Counters1 = fabric_dict:update_counter(From, length(Reply), Counters0),
-
-        % Drop any chunks that have been sent to all writers
-        Size = fabric_dict:size(Counters1),
-        NumToDrop = lists:min([I || {_, I} <- Counters1]),
-
-        {ChunkList3, Counters3} =
-        if Size == N andalso NumToDrop > 0 ->
-            ChunkList2 = lists:nthtail(NumToDrop, ChunkList1),
-            Counters2 = [{F, I-NumToDrop} || {F, I} <- Counters1],
-            {ChunkList2, Counters2};
-        true ->
-            {ChunkList1, Counters1}
-        end,
-
-        middleman_loop(Receiver, N, Counters3, ChunkList3, Timeout)
-    after Timeout ->
-        exit(Receiver, kill),
-        ok
-    end.