Inheritance diagram for Ftp::Gateway:
Collaboration diagram for Ftp::Gateway:

Public Types

enum  {
  BEGIN,
  SENT_USER,
  SENT_PASS,
  SENT_TYPE,
  SENT_MDTM,
  SENT_SIZE,
  SENT_EPRT,
  SENT_PORT,
  SENT_EPSV_ALL,
  SENT_EPSV_1,
  SENT_EPSV_2,
  SENT_PASV,
  SENT_CWD,
  SENT_LIST,
  SENT_NLST,
  SENT_REST,
  SENT_RETR,
  SENT_STOR,
  SENT_QUIT,
  READING_DATA,
  WRITING_DATA,
  SENT_MKDIR,
  SENT_FEAT,
  SENT_PWD,
  SENT_CDUP,
  SENT_DATA_REQUEST,
  SENT_COMMAND,
  END
}
 
typedef CbcPointer< AsyncJobPointer
 
typedef CbcPointer< BodyProducerPointer
 
typedef CbcPointer< BodyConsumerPointer
 

Public Member Functions

 Gateway (FwdState *)
 
 ~Gateway () override
 
void start () override
 called by AsyncStart; do not call directly More...
 
Http::StatusCode failedHttpStatus (err_type &error) override
 
int restartable ()
 
void appendSuccessHeader ()
 
void hackShortcut (StateMethod *nextState)
 
void unhack ()
 
void readStor ()
 
void parseListing ()
 
bool htmlifyListEntry (const char *line, PackableStream &)
 
void completedListing (void)
 
void listenForDataChannel (const Comm::ConnectionPointer &conn)
 create a data channel acceptor and start listening. More...
 
int checkAuth (const HttpHeader *req_hdr)
 
void checkUrlpath ()
 
std::optional< SBufdecodedRequestUriPath () const
 absolute request URI path after successful decoding of all pct-encoding sequences More...
 
void buildTitleUrl ()
 
void writeReplyBody (const char *, size_t len)
 
void completeForwarding () override
 
void processHeadResponse ()
 
void processReplyBody () override
 
void setCurrentOffset (int64_t offset)
 
int64_t getCurrentOffset () const
 
void dataChannelConnected (const CommConnectCbParams &io) override
 
void timeout (const CommTimeoutCbParams &io) override
 read timeout handler More...
 
void ftpAcceptDataConnection (const CommAcceptCbParams &io)
 
SBuf ftpRealm ()
 
void loginFailed (void)
 
void haveParsedReplyHeaders () override
 called when we have final (possibly adapted) reply headers; kids extend More...
 
virtual bool haveControlChannel (const char *caller_name) const
 
virtual void failed (err_type error=ERR_NONE, int xerrno=0, ErrorState *ftperr=nullptr)
 handle a fatal transaction error, closing the control connection More...
 
void maybeReadVirginBody () override
 read response data from the network More...
 
void writeCommand (const char *buf)
 
bool handlePasvReply (Ip::Address &remoteAddr)
 
bool handleEpsvReply (Ip::Address &remoteAddr)
 
bool sendEprt ()
 
bool sendPort ()
 
bool sendPassive ()
 
void connectDataChannel ()
 
bool openListenSocket ()
 
void switchTimeoutToDataChannel ()
 
void noteMoreBodyDataAvailable (BodyPipe::Pointer) override
 
void noteBodyProductionEnded (BodyPipe::Pointer) override
 
void noteBodyProducerAborted (BodyPipe::Pointer) override
 
virtual bool abortOnData (const char *reason)
 
virtual HttpRequestPointer originalRequest ()
 a hack to reach HttpStateData::orignal_request More...
 
void noteAdaptationAnswer (const Adaptation::Answer &answer) override
 
void noteAdaptationAclCheckDone (Adaptation::ServiceGroupPointer group) override
 
void noteMoreBodySpaceAvailable (BodyPipe::Pointer) override
 
void noteBodyConsumerAborted (BodyPipe::Pointer) override
 
virtual bool getMoreRequestBody (MemBuf &buf)
 either fill buf with available [encoded] request body bytes or return false More...
 
void swanSong () override
 
bool doneAll () const override
 whether positive goal has been reached More...
 
void serverComplete ()
 
void markParsedVirginReplyAsWhole (const char *reasonWeAreSure)
 
bool canBeCalled (AsyncCall &call) const
 whether we can be called More...
 
void callStart (AsyncCall &call)
 
virtual void callEnd ()
 called right after the called job method More...
 
virtual void callException (const std::exception &e)
 called when the job throws during an async call More...
 
void handleStopRequest ()
 process external request to terminate now (i.e. during this async call) More...
 
virtual void * toCbdata ()=0
 

Static Public Member Functions

static HttpReplyftpAuthRequired (HttpRequest *request, SBuf &realm, AccessLogEntry::Pointer &)
 
static void Start (const Pointer &job)
 
static void RegisterWithCacheManager ()
 

Public Attributes

char user [MAX_URL]
 
char password [MAX_URL]
 
int password_url
 
char * reply_hdr
 
int reply_hdr_state
 
String clean_url
 
String title_url
 
String base_href
 
int conn_att
 
int login_att
 
time_t mdtm
 
int64_t theSize
 
wordlistpathcomps
 
char * filepath
 
char * dirpath
 
int64_t restart_offset
 
char * proxy_host
 
size_t list_width
 
String cwd_message
 
char * old_filepath
 
char typecode
 
MemBuf listing
 FTP directory listing in HTML format. More...
 
GatewayFlags flags
 
CtrlChannel ctrl
 FTP control channel state. More...
 
DataChannel data
 FTP data channel state. More...
 
enum Ftp::Client:: { ... }  ftp_state_t
 
int state
 
char * old_request
 
char * old_reply
 
StoreEntryentry = nullptr
 
FwdState::Pointer fwd
 
HttpRequestPointer request
 
const InstanceId< AsyncJobid
 job identifier More...
 

Static Public Attributes

static PF ftpDataWrite
 

Protected Member Functions

void handleControlReply () override
 
void dataClosed (const CommCloseCbParams &io) override
 handler called by Comm when FTP data channel is closed unexpectedly More...
 
void closeServer () override
 
bool doneWithServer () const override
 
const Comm::ConnectionPointerdataConnection () const override
 
void abortAll (const char *reason) override
 abnormal transaction termination; reason is for debugging only More...
 
void noteDelayAwareReadChance () override
 
void ctrlClosed (const CommCloseCbParams &io)
 handler called by Comm when FTP control channel is closed unexpectedly More...
 
void scheduleReadControlReply (int buffered_ok)
 
void readControlReply (const CommIoCbParams &io)
 
void writeCommandCallback (const CommIoCbParams &io)
 
void dataRead (const CommIoCbParams &io)
 
void dataComplete ()
 
AsyncCall::Pointer dataCloser ()
 creates a data channel Comm close callback More...
 
void initReadBuf ()
 
void sentRequestBody (const CommIoCbParams &io) override
 
void doneSendingRequestBody () override
 
bool startRequestBodyFlow ()
 
void handleMoreRequestBodyAvailable ()
 
void handleRequestBodyProductionEnded ()
 
void sendMoreRequestBody ()
 
bool abortOnBadEntry (const char *abortReason)
 Entry-dependent callbacks use this check to quit if the entry went bad. More...
 
bool blockCaching ()
 whether to prevent caching of an otherwise cachable response More...
 
void startAdaptation (const Adaptation::ServiceGroupPointer &group, HttpRequest *cause)
 Initiate an asynchronous adaptation transaction which will call us back. More...
 
void adaptVirginReplyBody (const char *buf, ssize_t len)
 
void cleanAdaptation ()
 
virtual bool doneWithAdaptation () const
 
void handleMoreAdaptedBodyAvailable ()
 
void handleAdaptedBodyProductionEnded ()
 
void handleAdaptedBodyProducerAborted ()
 
void handleAdaptedHeader (Http::Message *msg)
 
void handleAdaptationCompleted ()
 
void handleAdaptationBlocked (const Adaptation::Answer &answer)
 
void handleAdaptationAborted (bool bypassable=false)
 
bool handledEarlyAdaptationAbort ()
 
void resumeBodyStorage ()
 called by StoreEntry when it has more buffer space available More...
 
void checkAdaptationWithBodyCompletion ()
 
const HttpReplyvirginReply () const
 
HttpReplyvirginReply ()
 
HttpReplysetVirginReply (HttpReply *r)
 
HttpReplyfinalReply ()
 
HttpReplysetFinalReply (HttpReply *r)
 
void adaptOrFinalizeReply ()
 
void addVirginReplyBody (const char *buf, ssize_t len)
 
void storeReplyBody (const char *buf, ssize_t len)
 
size_t calcBufferSpaceToReserve (const size_t space, const size_t wantSpace) const
 determine how much space the buffer needs to reserve More...
 
void adjustBodyBytesRead (const int64_t delta)
 initializes bodyBytesRead stats if needed and applies delta More...
 
void delayRead ()
 
CbcPointer< Initiate > initiateAdaptation (Initiate *x)
 < starts freshly created initiate and returns a safe pointer to it More...
 
void clearAdaptation (CbcPointer< Initiate > &x)
 clears the pointer (does not call announceInitiatorAbort) More...
 
void announceInitiatorAbort (CbcPointer< Initiate > &x)
 inform the transaction about abnormal termination and clear the pointer More...
 
bool initiated (const CbcPointer< AsyncJob > &job) const
 Must(initiated(initiate)) instead of Must(initiate.set()), for clarity. More...
 
void deleteThis (const char *aReason)
 
void mustStop (const char *aReason)
 
bool done () const
 the job is destroyed in callEnd() when done() More...
 
virtual const char * status () const
 internal cleanup; do not call directly More...
 
void stopProducingFor (RefCount< BodyPipe > &, bool atEof)
 
void stopConsumingFrom (RefCount< BodyPipe > &)
 

Static Protected Member Functions

static void ReportAllJobs (StoreEntry *)
 writes a cache manager report about all jobs existing in this worker More...
 

Protected Attributes

JobWait< Comm::ConnOpenerdataConnWait
 
int64_t currentOffset = 0
 
MemBufresponseBodyBuffer = nullptr
 
BodyPipe::Pointer requestBodySource
 
AsyncCall::Pointer requestSender
 
BodyPipe::Pointer virginBodyDestination
 
CbcPointer< Adaptation::InitiateadaptedHeadSource
 
BodyPipe::Pointer adaptedBodySource
 
bool adaptationAccessCheckPending = false
 
bool startedAdaptation = false
 
bool receivedWholeAdaptedReply = false
 
bool adaptedReplyAborted = false
 handleAdaptedBodyProducerAborted() has been called More...
 
bool receivedWholeRequestBody = false
 handleRequestBodyProductionEnded called More...
 
bool waitingForDelayAwareReadChance = false
 whether we are waiting for MemObject::delayRead() to call us back More...
 
const char * markedParsedVirginReplyAsWhole = nullptr
 
const char * doneWithFwd = nullptr
 
const char * stopReason
 reason for forcing done() to be true More...
 
const char * typeName
 kid (leaf) class name, for debugging More...
 
AsyncCall::Pointer inCall
 the asynchronous call being handled, if any More...
 
bool started_ = false
 Start() has finished successfully. More...
 
bool swanSang_ = false
 swanSong() was called More...
 

Private Member Functions

 CBDATA_CHILD (Gateway)
 
bool mayReadVirginReplyBody () const override
 whether we may receive more virgin response body bytes More...
 
void handleRequestBodyProducerAborted () override
 
void loginParser (const SBuf &login, bool escaped)
 
 CBDATA_INTERMEDIATE ()
 
bool parseControlReply (size_t &bytesUsed)
 
void serverComplete2 ()
 
void sendBodyIsTooLargeError ()
 
void maybePurgeOthers ()
 
virtual void finalizedInCbdataChild ()=0
 hack: ensure CBDATA_CHILD() after a toCbdata()-defining CBDATA_INTERMEDIATE() More...
 

Private Attributes

bool shortenReadTimeout
 
bool completed = false
 
HttpReplytheVirginReply = nullptr
 
HttpReplytheFinalReply = nullptr
 

Detailed Description

FTP Gateway: An FTP client that takes an HTTP request with an ftp:// URI, converts it into one or more FTP commands, and then converts one or more FTP responses into the final HTTP response.

Definition at line 95 of file FtpGateway.cc.

Member Typedef Documentation

◆ Pointer [1/3]

Definition at line 25 of file BodyPipe.h.

◆ Pointer [2/3]

Definition at line 34 of file AsyncJob.h.

◆ Pointer [3/3]

Definition at line 45 of file BodyPipe.h.

Member Enumeration Documentation

◆ anonymous enum

anonymous enum
inherited
Enumerator
BEGIN 
SENT_USER 
SENT_PASS 
SENT_TYPE 
SENT_MDTM 
SENT_SIZE 
SENT_EPRT 
SENT_PORT 
SENT_EPSV_ALL 
SENT_EPSV_1 
SENT_EPSV_2 
SENT_PASV 
SENT_CWD 
SENT_LIST 
SENT_NLST 
SENT_REST 
SENT_RETR 
SENT_STOR 
SENT_QUIT 
READING_DATA 
WRITING_DATA 
SENT_MKDIR 
SENT_FEAT 
SENT_PWD 
SENT_CDUP 
SENT_DATA_REQUEST 
SENT_COMMAND 
END 

Definition at line 145 of file FtpClient.h.

Constructor & Destructor Documentation

◆ Gateway()

◆ ~Gateway()

Ftp::Gateway::~Gateway ( )
override

Member Function Documentation

◆ abortAll()

void Ftp::Client::abortAll ( const char *  reason)
overrideprotectedvirtualinherited

Implements Client.

Definition at line 1058 of file FtpClient.cc.

References debugs.

◆ abortOnBadEntry()

◆ abortOnData()

bool Client::abortOnData ( const char *  reason)
virtualinherited

abnormal data transfer termination

Return values
truethe transaction will be terminated (abortAll called)
falsethe transaction will survive

Reimplemented in Ftp::Relay.

Definition at line 315 of file Client.cc.

References Client::abortAll().

Referenced by Client::abortOnBadEntry(), Client::handleAdaptationBlocked(), Client::sendBodyIsTooLargeError(), and Client::sentRequestBody().

◆ adaptOrFinalizeReply()

◆ adaptVirginReplyBody()

void Client::adaptVirginReplyBody ( const char *  buf,
ssize_t  len 
)
protectedinherited

◆ addVirginReplyBody()

◆ adjustBodyBytesRead()

void Client::adjustBodyBytesRead ( const int64_t  delta)
protectedinherited

◆ announceInitiatorAbort()

void Adaptation::Initiator::announceInitiatorAbort ( CbcPointer< Initiate > &  x)
protectedinherited

Definition at line 38 of file Initiator.cc.

References CallJobHere.

Referenced by Client::cleanAdaptation(), and ClientHttpRequest::~ClientHttpRequest().

◆ appendSuccessHeader()

◆ blockCaching()

◆ buildTitleUrl()

void Ftp::Gateway::buildTitleUrl ( )

Definition at line 1120 of file FtpGateway.cc.

References SBuf::append(), AnyP::PROTO_FTP, and rfc1738_escape_part.

◆ calcBufferSpaceToReserve()

size_t Client::calcBufferSpaceToReserve ( const size_t  space,
const size_t  wantSpace 
) const
protectedinherited

◆ callEnd()

void AsyncJob::callEnd ( )
virtualinherited

◆ callException()

◆ callStart()

void AsyncJob::callStart ( AsyncCall call)
inherited

◆ canBeCalled()

bool AsyncJob::canBeCalled ( AsyncCall call) const
inherited

Definition at line 117 of file AsyncJob.cc.

References AsyncCall::cancel(), debugs, and AsyncJob::inCall.

◆ CBDATA_CHILD()

Ftp::Gateway::CBDATA_CHILD ( Gateway  )
private

◆ CBDATA_INTERMEDIATE()

Ftp::Client::CBDATA_INTERMEDIATE ( )
privateinherited

◆ checkAdaptationWithBodyCompletion()

void Client::checkAdaptationWithBodyCompletion ( )
protectedinherited

Reacts to adaptedBodySource-related changes. May end adapted body consumption, adaptation as a whole, or forwarding. Safe to call multiple times, including calls made after the end of adaptation.

Definition at line 831 of file Client.cc.

References Client::adaptedBodySource, Client::adaptedReplyAborted, debugs, Client::doneWithAdaptation(), BodyPipe::exhausted(), Client::handleAdaptationCompleted(), Client::receivedWholeAdaptedReply, Client::startedAdaptation, BodyPipe::status(), and BodyConsumer::stopConsumingFrom().

Referenced by Client::handleAdaptedBodyProducerAborted(), Client::handleAdaptedBodyProductionEnded(), Client::handleAdaptedHeader(), and Client::resumeBodyStorage().

◆ checkAuth()

int Ftp::Gateway::checkAuth ( const HttpHeader req_hdr)

Locates the FTP user:password login.

Highest to lowest priority:

  • Checks URL (ftp://user:pass@domain)
  • Authorization: Basic header
  • squid.conf anonymous-FTP settings (default: anonymous:Squid@).

Special Case: A username-only may be provided in the URL and password in the HTTP headers.

TODO: we might be able to do something about locating username from other sources: ie, external ACL user=* tag

Return values
1if we have everything needed to complete this request.
0if something is missing.

Definition at line 1035 of file FtpGateway.cc.

References SquidConfig::anon_user, Assure, Http::AUTHORIZATION, Config, SquidConfig::Ftp, HttpHeader::getAuthToken(), MAX_URL, null_string, and xstrncpy().

◆ checkUrlpath()

void Ftp::Gateway::checkUrlpath ( )

Definition at line 1080 of file FtpGateway.cc.

References SBuf::length(), SBuf::npos, and xtoupper.

◆ cleanAdaptation()

◆ clearAdaptation()

void Adaptation::Initiator::clearAdaptation ( CbcPointer< Initiate > &  x)
protectedinherited

◆ closeServer()

void Ftp::Client::closeServer ( )
overrideprotectedvirtualinherited

Close the FTP server connection(s). Used by serverComplete().

Implements Client.

Definition at line 234 of file FtpClient.cc.

References debugs, and Comm::IsConnOpen().

◆ completedListing()

void Ftp::Gateway::completedListing ( void  )

Generate the HTTP headers and template fluff around an FTP directory listing display.

Definition at line 2223 of file FtpGateway.cc.

References assert, ErrorState::BuildHttpReply(), ErrorState::cwd_msg, ERR_DIR_LISTING, ErrorState::ftp, ErrorState::listing, safe_free, Http::scOkay, ErrorState::server_msg, and xstrdup.

Referenced by ftpReadTransferDone().

◆ completeForwarding()

void Ftp::Gateway::completeForwarding ( )
overridevirtual

A hack to ensure we do not double-complete on the forward entry.

TODO: Ftp::Gateway logic should probably be rewritten to avoid double-completion or FwdState should be rewritten to allow it.

Reimplemented from Client.

Definition at line 2651 of file FtpGateway.cc.

References Client::completeForwarding(), and debugs.

◆ connectDataChannel()

◆ ctrlClosed()

void Ftp::Client::ctrlClosed ( const CommCloseCbParams io)
protectedinherited

Definition at line 880 of file FtpClient.cc.

References debugs.

Referenced by Ftp::Client::Client().

◆ dataChannelConnected()

void Ftp::Gateway::dataChannelConnected ( const CommConnectCbParams io)
overridevirtual

◆ dataClosed()

void Ftp::Gateway::dataClosed ( const CommCloseCbParams io)
overrideprotectedvirtual

Reimplemented from Ftp::Client.

Definition at line 318 of file FtpGateway.cc.

References Ftp::Client::dataClosed(), ERR_FTP_FAILURE, and Ftp::Client::failed().

◆ dataCloser()

AsyncCall::Pointer Ftp::Client::dataCloser ( )
protectedinherited

Definition at line 803 of file FtpClient.cc.

References Ftp::Client::dataClosed(), and JobCallback.

◆ dataComplete()

void Client::dataComplete ( )
protectedinherited

Close data channel, if any, to conserve resources while we wait.

Definition at line 1029 of file FtpClient.cc.

References debugs.

Referenced by Ftp::Relay::HandleStoreAbort().

◆ dataConnection()

const Comm::ConnectionPointer & Client::dataConnection ( ) const
overrideprotectedvirtualinherited
Returns
primary or "request data connection"

Implements Client.

Definition at line 903 of file FtpClient.cc.

◆ dataRead()

◆ decodedRequestUriPath()

std::optional< SBuf > Ftp::Gateway::decodedRequestUriPath ( ) const

Definition at line 2309 of file FtpGateway.cc.

References AnyP::Uri::Decode().

Referenced by ftpFail(), and ftpTrySlashHack().

◆ delayRead()

void Client::delayRead ( )
protectedinherited

Defer reading until it is likely to become possible. Eventually, noteDelayAwareReadChance() will be called.

Definition at line 1042 of file Client.cc.

References Assure, asyncCall(), MemObject::delayRead(), Client::entry, StoreEntry::mem(), Client::noteDelayAwareReadChance(), and Client::waitingForDelayAwareReadChance.

Referenced by HttpStateData::readReply().

◆ deleteThis()

void AsyncJob::deleteThis ( const char *  aReason)
protectedinherited

◆ done()

bool AsyncJob::done ( ) const
protectedinherited

◆ doneAll()

bool Client::doneAll ( ) const
overridevirtualinherited

Reimplemented from AsyncJob.

Definition at line 203 of file Client.cc.

References AsyncJob::doneAll(), Client::doneWithAdaptation(), and Client::doneWithServer().

◆ doneSendingRequestBody()

void Ftp::Client::doneSendingRequestBody ( )
overrideprotectedvirtualinherited

called after we wrote the last byte of the request body

Implements Client.

Definition at line 1092 of file FtpClient.cc.

References debugs, and Client::doneSendingRequestBody().

◆ doneWithAdaptation()

◆ doneWithServer()

bool Ftp::Client::doneWithServer ( ) const
overrideprotectedvirtualinherited

Did we close all FTP server connection(s)?

Return values
trueBoth server control and data channels are closed. And not waiting for a new data connection to open.
falseEither control channel or data is still active.

Implements Client.

Definition at line 257 of file FtpClient.cc.

References Comm::IsConnOpen().

◆ failed()

◆ failedHttpStatus()

Http::StatusCode Ftp::Gateway::failedHttpStatus ( err_type error)
overridevirtual

◆ finalizedInCbdataChild()

virtual void CbdataParent::finalizedInCbdataChild ( )
privatepure virtualinherited

◆ finalReply()

HttpReply * Client::finalReply ( )
protectedinherited

Definition at line 129 of file Client.cc.

References assert, and Client::theFinalReply.

Referenced by HttpStateData::haveParsedReplyHeaders(), and HttpStateData::reusableReply().

◆ ftpAcceptDataConnection()

void Ftp::Gateway::ftpAcceptDataConnection ( const CommAcceptCbParams io)

"read" handler to accept FTP data connections.

Parameters
iocomm accept(2) callback parameters
When squid.conf ftp_sanitycheck is enabled, check the new connection is actually being made by the remote client which is connected to the FTP control socket. Or the one which we were told to listen for by control channel messages (may differ under NAT). This prevents third-party hacks, but also third-party load balancing handshakes.

On Comm::OK start using the accepted data socket and discard the temporary listen socket.

Definition at line 1884 of file FtpGateway.cc.

References assert, Comm::Connection::close(), Config, CommCommonCbParams::conn, DBG_IMPORTANT, debugs, EBIT_TEST, ENTRY_ABORTED, fd_table, CommCommonCbParams::flag, SquidConfig::Ftp, ftpFail, Comm::IsConnOpen(), MYNAME, Comm::OK, Comm::Connection::remote, SquidConfig::sanitycheck, CommCommonCbParams::xerrno, and xstrerr().

Referenced by listenForDataChannel().

◆ ftpAuthRequired()

HttpReply * Ftp::Gateway::ftpAuthRequired ( HttpRequest request,
SBuf realm,
AccessLogEntry::Pointer ale 
)
static

◆ ftpRealm()

SBuf Ftp::Gateway::ftpRealm ( )

Definition at line 1270 of file FtpGateway.cc.

References SBuf::append(), and SBuf::appendf().

◆ getCurrentOffset()

int64_t Ftp::Gateway::getCurrentOffset ( ) const
inline

Definition at line 152 of file FtpGateway.cc.

References Client::currentOffset.

◆ getMoreRequestBody()

bool Client::getMoreRequestBody ( MemBuf buf)
virtualinherited

◆ hackShortcut()

void Ftp::Gateway::hackShortcut ( StateMethod nextState)

Definition at line 2351 of file FtpGateway.cc.

References debugs, MYNAME, and xstrdup.

Referenced by ftpFail(), and ftpReadRetr().

◆ handleAdaptationAborted()

void Client::handleAdaptationAborted ( bool  bypassable = false)
protectedinherited

◆ handleAdaptationBlocked()

◆ handleAdaptationCompleted()

◆ handleAdaptedBodyProducerAborted()

◆ handleAdaptedBodyProductionEnded()

void Client::handleAdaptedBodyProductionEnded ( )
protectedinherited

◆ handleAdaptedHeader()

◆ handleControlReply()

void Ftp::Gateway::handleControlReply ( )
overrideprotectedvirtual

Reimplemented from Ftp::Client.

Definition at line 1175 of file FtpGateway.cc.

References FTP_SM_FUNCS, Ftp::Client::handleControlReply(), and wordlist::next.

◆ handledEarlyAdaptationAbort()

bool Client::handledEarlyAdaptationAbort ( )
protectedinherited

If the store entry is still empty, fully handles adaptation abort, returning true. Otherwise just updates the request error detail and returns false.

Definition at line 913 of file Client.cc.

References Client::abortAll(), FwdState::al, debugs, HttpRequest::detailError(), FwdState::dontRetry(), Client::entry, ERR_ICAP_FAILURE, FwdState::fail(), Client::fwd, RefCount< C >::getRaw(), StoreEntry::isEmpty(), MakeNamedErrorDetail(), Client::request, and Http::scInternalServerError.

Referenced by Client::handleAdaptationAborted(), and Client::handleAdaptedBodyProducerAborted().

◆ handleEpsvReply()

bool Client::handleEpsvReply ( Ip::Address remoteAddr)
inherited

◆ handleMoreAdaptedBodyAvailable()

◆ handleMoreRequestBodyAvailable()

void Client::handleMoreRequestBodyAvailable ( )
protectedinherited

◆ handlePasvReply()

bool Client::handlePasvReply ( Ip::Address remoteAddr)
inherited

extracts remoteAddr from PASV response, validates it, sets data address details, and returns true on success

Definition at line 456 of file FtpClient.cc.

References Config, DBG_IMPORTANT, debugs, fd_table, SquidConfig::Ftp, Comm::IsConnOpen(), Ftp::ParseIpPort(), and SquidConfig::sanitycheck.

Referenced by ftpReadPasv().

◆ handleRequestBodyProducerAborted()

void Ftp::Gateway::handleRequestBodyProducerAborted ( )
overrideprivatevirtual

Implements Client.

Definition at line 2262 of file FtpGateway.cc.

References debugs, ERR_READ_ERROR, and Client::handleRequestBodyProducerAborted().

◆ handleRequestBodyProductionEnded()

void Client::handleRequestBodyProductionEnded ( )
protectedinherited

◆ handleStopRequest()

void AsyncJob::handleStopRequest ( )
inlineinherited

Definition at line 73 of file AsyncJob.h.

References AsyncJob::mustStop().

◆ haveControlChannel()

bool Ftp::Gateway::haveControlChannel ( const char *  caller_name) const
virtual

Have we lost the FTP server control channel?

Return values
trueThe server control channel is available.
falseThe server control channel is not available.

Definition at line 2671 of file FtpGateway.cc.

References DBG_IMPORTANT, debugs, and Comm::IsConnOpen().

Referenced by ftpSendCwd(), ftpSendList(), ftpSendMdtm(), ftpSendMkdir(), ftpSendNlst(), ftpSendPass(), ftpSendPassive(), ftpSendPORT(), ftpSendQuit(), ftpSendRest(), ftpSendRetr(), ftpSendSize(), ftpSendStor(), ftpSendType(), and ftpSendUser().

◆ haveParsedReplyHeaders()

void Ftp::Gateway::haveParsedReplyHeaders ( )
overridevirtual

called when got final headers

Reimplemented from Client.

Definition at line 2581 of file FtpGateway.cc.

References Client::haveParsedReplyHeaders(), StoreEntry::makePublic(), StoreEntry::release(), and StoreEntry::timestampsSet().

◆ htmlifyListEntry()

◆ initiateAdaptation()

CbcPointer< Adaptation::Initiate > Adaptation::Initiator::initiateAdaptation ( Initiate x)
protectedinherited

◆ initiated()

bool Adaptation::Initiator::initiated ( const CbcPointer< AsyncJob > &  job) const
inlineprotectedinherited

Definition at line 52 of file Initiator.h.

Referenced by Client::startAdaptation(), and ClientHttpRequest::startAdaptation().

◆ initReadBuf()

void Client::initReadBuf ( )
protectedinherited

Definition at line 222 of file FtpClient.cc.

References MemBuf::init().

Referenced by Gateway().

◆ listenForDataChannel()

◆ loginFailed()

void Ftp::Gateway::loginFailed ( void  )

Translate FTP login failure into HTTP error this is an attempt to get the 407 message to show up outside Squid. its NOT a general failure. But a correct FTP response type.

Definition at line 1226 of file FtpGateway.cc.

References ErrorState::BuildHttpReply(), SBuf::c_str(), ERR_FTP_FORBIDDEN, ERR_FTP_UNAVAILABLE, ERR_NONE, ftpFail, Http::Message::header, HttpHeader::putAuth(), Http::scForbidden, Http::scServiceUnavailable, and Http::scUnauthorized.

Referenced by ftpReadPass(), and ftpReadUser().

◆ loginParser()

void Ftp::Gateway::loginParser ( const SBuf login,
bool  escaped 
)
private

Parse a possible login username:password pair. Produces filled member variables user, password, password_url if anything found.

Parameters
logina decoded Basic authentication credential token or URI user-info token
escapedwhether to URL-decode the token after extracting user and password

Definition at line 399 of file FtpGateway.cc.

References SBuf::copy(), debugs, SBuf::find(), SBuf::isEmpty(), SBuf::length(), SBuf::npos, rfc1738_unescape(), and SBuf::substr().

◆ markParsedVirginReplyAsWhole()

void Client::markParsedVirginReplyAsWhole ( const char *  reasonWeAreSure)
inherited

remember that the received virgin reply was parsed in its entirety, including its body (if any)

Definition at line 158 of file Client.cc.

References assert, debugs, and Client::markedParsedVirginReplyAsWhole.

Referenced by HttpStateData::decodeAndWriteReplyBody(), ftpReadTransferDone(), ftpWriteTransferDone(), and HttpStateData::writeReplyBody().

◆ maybePurgeOthers()

◆ maybeReadVirginBody()

void Client::maybeReadVirginBody ( )
overridevirtualinherited

◆ mayReadVirginReplyBody()

bool Ftp::Gateway::mayReadVirginReplyBody ( ) const
overrideprivatevirtual

Implements Client.

Definition at line 2687 of file FtpGateway.cc.

◆ mustStop()

◆ noteAdaptationAclCheckDone()

void Client::noteAdaptationAclCheckDone ( Adaptation::ServiceGroupPointer  group)
overridevirtualinherited

AccessCheck calls this back with a possibly nil service group to signal whether adaptation is needed and where it should start.

Reimplemented from Adaptation::Initiator.

Definition at line 970 of file Client.cc.

References Client::abortOnBadEntry(), Client::adaptationAccessCheckPending, debugs, Client::originalRequest(), Client::processReplyBody(), Client::request, Client::sendBodyIsTooLargeError(), Client::setFinalReply(), Client::startAdaptation(), and Client::virginReply().

◆ noteAdaptationAnswer()

void Client::noteAdaptationAnswer ( const Adaptation::Answer answer)
overridevirtualinherited

◆ noteBodyConsumerAborted()

void Client::noteBodyConsumerAborted ( BodyPipe::Pointer  )
overridevirtualinherited

◆ noteBodyProducerAborted()

void Client::noteBodyProducerAborted ( BodyPipe::Pointer  bp)
overridevirtualinherited

◆ noteBodyProductionEnded()

void Client::noteBodyProductionEnded ( BodyPipe::Pointer  bp)
overridevirtualinherited

◆ noteDelayAwareReadChance()

void Client::noteDelayAwareReadChance ( )
overrideprotectedvirtualinherited

Called when a previously delayed dataConnection() read may be possible.

See also
delayRead()

Implements Client.

Definition at line 909 of file FtpClient.cc.

◆ noteMoreBodyDataAvailable()

void Client::noteMoreBodyDataAvailable ( BodyPipe::Pointer  bp)
overridevirtualinherited

◆ noteMoreBodySpaceAvailable()

void Client::noteMoreBodySpaceAvailable ( BodyPipe::Pointer  )
overridevirtualinherited

◆ openListenSocket()

bool Client::openListenSocket ( )
inherited

Definition at line 796 of file FtpClient.cc.

◆ originalRequest()

◆ parseControlReply()

bool Ftp::Client::parseControlReply ( size_t bytesUsed)
privateinherited

Parses FTP server control response into ctrl structure fields, setting bytesUsed and returning true on success.

Definition at line 1106 of file FtpClient.cc.

References assert, Ftp::crlf, debugs, head, wordlist::key, wordlist::next, safe_free, wordlistDestroy(), xmalloc, xstrdup, and xstrncpy().

◆ parseListing()

void Ftp::Gateway::parseListing ( )

◆ processHeadResponse()

void Ftp::Gateway::processHeadResponse ( )

Definition at line 1691 of file FtpGateway.cc.

References debugs, EBIT_TEST, ENTRY_ABORTED, and ftpSendQuit.

Referenced by ftpSendPassive().

◆ processReplyBody()

void Ftp::Gateway::processReplyBody ( )
overridevirtual

Implements Client.

Definition at line 968 of file FtpGateway.cc.

References debugs, EBIT_TEST, ENTRY_ABORTED, and Http::METHOD_HEAD.

◆ readControlReply()

◆ readStor()

void Ftp::Gateway::readStor ( )

Definition at line 2015 of file FtpGateway.cc.

References DBG_IMPORTANT, debugs, ftpFail, Comm::IsConnOpen(), and MYNAME.

Referenced by ftpReadStor().

◆ RegisterWithCacheManager()

void AsyncJob::RegisterWithCacheManager ( )
staticinherited

Definition at line 215 of file AsyncJob.cc.

References Mgr::RegisterAction(), and AsyncJob::ReportAllJobs().

Referenced by mainInitialize().

◆ ReportAllJobs()

void AsyncJob::ReportAllJobs ( StoreEntry e)
staticprotectedinherited

Definition at line 198 of file AsyncJob.cc.

References AllJobs().

Referenced by AsyncJob::RegisterWithCacheManager().

◆ restartable()

int Ftp::Gateway::restartable ( )

Definition at line 2065 of file FtpGateway.cc.

Referenced by ftpRestOrList().

◆ resumeBodyStorage()

void Client::resumeBodyStorage ( )
protectedinherited

◆ scheduleReadControlReply()

void Ftp::Client::scheduleReadControlReply ( int  buffered_ok)
protectedinherited

DPW 2007-04-23 Looks like there are no longer anymore callers that set buffered_ok=1. Perhaps it can be removed at some point.

Definition at line 326 of file FtpClient.cc.

References comm_read(), commSetConnTimeout(), commUnsetConnTimeout(), Config, SquidConfig::connect, debugs, Comm::IsConnOpen(), JobCallback, min(), SquidConfig::read, Ftp::Client::readControlReply(), Ftp::Client::timeout(), and SquidConfig::Timeout.

Referenced by Ftp::Relay::scheduleReadControlReply().

◆ sendBodyIsTooLargeError()

void Client::sendBodyIsTooLargeError ( )
privateinherited

◆ sendEprt()

◆ sendMoreRequestBody()

◆ sendPassive()

bool Client::sendPassive ( )
inherited
Checks for EPSV ALL special conditions: If enabled to be sent, squid MUST NOT request any other connect methods. If 'ALL' is sent and fails the entire FTP Session fails. NP: By my reading exact EPSV protocols maybe attempted, but only EPSV method.

Closes any old FTP-Data connection which may exist. *‍/

Checks for previous EPSV/PASV failures on this server/session. Diverts to EPRT immediately if they are not working.
Send EPSV (ALL,2,1) or PASV on the control channel.
  • EPSV ALL is used if enabled.
  • EPSV 2 is used if ALL is disabled and IPv6 is available and ctrl channel is IPv6.
  • EPSV 1 is used if EPSV 2 (IPv6) fails or is not available or ctrl channel is IPv4.
  • PASV is used if EPSV 1 fails.

Definition at line 654 of file FtpClient.cc.

References SquidConfig::accessList, Acl::Answer::allowed(), Packable::appendf(), Config, MemBuf::content(), Ftp::crlf, DBG_IMPORTANT, debugs, SquidConfig::epsv_all, ERR_FTP_FAILURE, ACLChecklist::fastCheck(), SquidConfig::Ftp, SquidConfig::ftp_epsv, SquidConfig::passive, MemBuf::reset(), and wordlistDestroy().

Referenced by ftpSendPassive().

◆ sendPort()

bool Client::sendPort ( )
inherited

Definition at line 647 of file FtpClient.cc.

References ERR_FTP_FAILURE.

◆ sentRequestBody()

void Client::sentRequestBody ( const CommIoCbParams io)
overrideprotectedvirtualinherited

◆ serverComplete()

◆ serverComplete2()

void Client::serverComplete2 ( )
privateinherited

◆ setCurrentOffset()

void Ftp::Gateway::setCurrentOffset ( int64_t  offset)
inline

Definition at line 151 of file FtpGateway.cc.

References Client::currentOffset.

Referenced by ftpReadRest().

◆ setFinalReply()

◆ setVirginReply()

HttpReply * Client::setVirginReply ( HttpReply r)
protectedinherited

◆ start()

void Ftp::Gateway::start ( )
overridevirtual

Reimplemented from Ftp::Client.

Definition at line 1153 of file FtpGateway.cc.

References debugs, and Ftp::Client::start().

◆ Start()

void AsyncJob::Start ( const Pointer job)
staticinherited

◆ startAdaptation()

◆ startRequestBodyFlow()

bool Client::startRequestBodyFlow ( )
protectedinherited

◆ status()

◆ stopConsumingFrom()

◆ stopProducingFor()

void BodyProducer::stopProducingFor ( RefCount< BodyPipe > &  p,
bool  atEof 
)
protectedinherited

◆ storeReplyBody()

void Client::storeReplyBody ( const char *  buf,
ssize_t  len 
)
protectedinherited

Definition at line 1070 of file Client.cc.

References Client::currentOffset, Client::entry, and StoreEntry::write().

Referenced by Client::addVirginReplyBody().

◆ swanSong()

◆ switchTimeoutToDataChannel()

void Ftp::Client::switchTimeoutToDataChannel ( )
inherited

Cancel the timeout on the Control socket and establish one on the data socket

Definition at line 1070 of file FtpClient.cc.

References commSetConnTimeout(), commUnsetConnTimeout(), Config, JobCallback, SquidConfig::read, Ftp::Client::timeout(), and SquidConfig::Timeout.

Referenced by ftpReadList(), and ftpReadRetr().

◆ timeout()

void Ftp::Gateway::timeout ( const CommTimeoutCbParams io)
overridevirtual

Reimplemented from Ftp::Client.

Definition at line 488 of file FtpGateway.cc.

References DBG_IMPORTANT, debugs, and Ftp::Client::timeout().

◆ toCbdata()

virtual void* CbdataParent::toCbdata ( )
pure virtualinherited

◆ unhack()

void Ftp::Gateway::unhack ( )

Forget hack status. Next error is shown to the user

Definition at line 2340 of file FtpGateway.cc.

References debugs, MYNAME, and safe_free.

Referenced by ftpReadCwd(), ftpReadMdtm(), and ftpReadSize().

◆ virginReply() [1/2]

HttpReply* Client::virginReply ( )
protectedinherited

◆ virginReply() [2/2]

◆ writeCommand()

◆ writeCommandCallback()

◆ writeReplyBody()

void Ftp::Gateway::writeReplyBody ( const char *  dataToWrite,
size_t  dataLength 
)

Call this when there is data from the origin server which should be sent to either StoreEntry, or to ICAP...

Definition at line 2638 of file FtpGateway.cc.

References debugs.

Member Data Documentation

◆ adaptationAccessCheckPending

bool Client::adaptationAccessCheckPending = false
protectedinherited

◆ adaptedBodySource

◆ adaptedHeadSource

CbcPointer<Adaptation::Initiate> Client::adaptedHeadSource
protectedinherited

to get adapted response headers

Definition at line 187 of file Client.h.

Referenced by Client::cleanAdaptation(), Client::doneWithAdaptation(), Client::noteAdaptationAnswer(), and Client::startAdaptation().

◆ adaptedReplyAborted

bool Client::adaptedReplyAborted = false
protectedinherited

◆ base_href

String Ftp::Gateway::base_href

Definition at line 109 of file FtpGateway.cc.

◆ clean_url

String Ftp::Gateway::clean_url

Definition at line 107 of file FtpGateway.cc.

◆ completed

bool Client::completed = false
privateinherited

serverComplete() has been called

Definition at line 90 of file Client.h.

Referenced by Client::noteMoreBodySpaceAvailable(), and Client::serverComplete().

◆ conn_att

int Ftp::Gateway::conn_att

Definition at line 110 of file FtpGateway.cc.

◆ ctrl

◆ currentOffset

int64_t Client::currentOffset = 0
protectedinherited

◆ cwd_message

String Ftp::Gateway::cwd_message

Definition at line 120 of file FtpGateway.cc.

Referenced by ftpReadCwd().

◆ data

DataChannel Ftp::Client::data
inherited

◆ dataConnWait

JobWait<Comm::ConnOpener> Ftp::Client::dataConnWait
protectedinherited

Waits for an FTP data connection to the server to be established/opened. This wait only happens in FTP passive mode (via PASV or EPSV).

Definition at line 210 of file FtpClient.h.

◆ dirpath

char* Ftp::Gateway::dirpath

Definition at line 116 of file FtpGateway.cc.

Referenced by ftpTraverseDirectory().

◆ doneWithFwd

const char* Client::doneWithFwd = nullptr
protectedinherited

whether we should not be talking to FwdState; XXX: clear fwd instead points to a string literal which is used only for debugging

Definition at line 211 of file Client.h.

Referenced by Client::completeForwarding(), HttpStateData::httpStateConnClosed(), HttpStateData::proceedAfter1xx(), and Client::swanSong().

◆ entry

◆ filepath

◆ flags

◆ ftp_state_t

enum { ... } Ftp::Client::ftp_state_t

◆ ftpDataWrite

PF Ftp::Gateway::ftpDataWrite
static

Definition at line 155 of file FtpGateway.cc.

◆ fwd

◆ id

const InstanceId<AsyncJob> AsyncJob::id
inherited

Definition at line 75 of file AsyncJob.h.

◆ inCall

AsyncCall::Pointer AsyncJob::inCall
protectedinherited

◆ list_width

size_t Ftp::Gateway::list_width

Definition at line 119 of file FtpGateway.cc.

◆ listing

MemBuf Ftp::Gateway::listing

Definition at line 123 of file FtpGateway.cc.

◆ login_att

int Ftp::Gateway::login_att

Definition at line 111 of file FtpGateway.cc.

Referenced by ftpReadWelcome().

◆ markedParsedVirginReplyAsWhole

const char* Client::markedParsedVirginReplyAsWhole = nullptr
protectedinherited

markParsedVirginReplyAsWhole() parameter (if that method was called) or nil; points to a string literal which is used only for debugging

Definition at line 207 of file Client.h.

Referenced by Client::completeForwarding(), and Client::markParsedVirginReplyAsWhole().

◆ mdtm

time_t Ftp::Gateway::mdtm

Definition at line 112 of file FtpGateway.cc.

Referenced by ftpFail(), ftpReadMdtm(), and ftpSendReply().

◆ old_filepath

char* Ftp::Gateway::old_filepath

Definition at line 121 of file FtpGateway.cc.

◆ old_reply

char* Ftp::Client::old_reply
inherited

Definition at line 178 of file FtpClient.h.

Referenced by ftpSendReply().

◆ old_request

char* Ftp::Client::old_request
inherited

Definition at line 177 of file FtpClient.h.

Referenced by ftpSendReply().

◆ password

char Ftp::Gateway::password[MAX_URL]

Definition at line 103 of file FtpGateway.cc.

Referenced by ftpSendPass(), and Gateway().

◆ password_url

int Ftp::Gateway::password_url

Definition at line 104 of file FtpGateway.cc.

◆ pathcomps

wordlist* Ftp::Gateway::pathcomps

Definition at line 114 of file FtpGateway.cc.

Referenced by ftpReadType(), ftpTraverseDirectory(), and ftpTrySlashHack().

◆ proxy_host

char* Ftp::Gateway::proxy_host

Definition at line 118 of file FtpGateway.cc.

Referenced by ftpSendUser().

◆ receivedWholeAdaptedReply

bool Client::receivedWholeAdaptedReply = false
protectedinherited

Whether the entire adapted response (including bodyless responses) has been successfully produced. A successful end of body production does not imply that we have consumed all of the produced body bytes.

Definition at line 196 of file Client.h.

Referenced by Client::checkAdaptationWithBodyCompletion(), Client::completeForwarding(), Client::handleAdaptedBodyProducerAborted(), Client::handleAdaptedBodyProductionEnded(), and Client::handleAdaptedHeader().

◆ receivedWholeRequestBody

bool Client::receivedWholeRequestBody = false
protectedinherited

◆ reply_hdr

char* Ftp::Gateway::reply_hdr

Definition at line 105 of file FtpGateway.cc.

◆ reply_hdr_state

int Ftp::Gateway::reply_hdr_state

Definition at line 106 of file FtpGateway.cc.

◆ request

◆ requestBodySource

◆ requestSender

◆ responseBodyBuffer

MemBuf* Client::responseBodyBuffer = nullptr
protectedinherited

◆ restart_offset

int64_t Ftp::Gateway::restart_offset

Definition at line 117 of file FtpGateway.cc.

Referenced by ftpReadRest(), and ftpSendRest().

◆ shortenReadTimeout

bool Ftp::Client::shortenReadTimeout
privateinherited

XXX: An old hack for FTP servers like ftp.netscape.com that may not respond to PASV. Use faster connect timeout instead of read timeout.

Definition at line 217 of file FtpClient.h.

◆ started_

bool AsyncJob::started_ = false
protectedinherited

Definition at line 88 of file AsyncJob.h.

Referenced by AsyncJob::callEnd(), AsyncJob::Start(), and AsyncJob::~AsyncJob().

◆ startedAdaptation

bool Client::startedAdaptation = false
protectedinherited

◆ state

◆ stopReason

const char* AsyncJob::stopReason
protectedinherited

◆ swanSang_

bool AsyncJob::swanSang_ = false
protectedinherited

Definition at line 89 of file AsyncJob.h.

Referenced by AsyncJob::callEnd(), and AsyncJob::~AsyncJob().

◆ theFinalReply

HttpReply* Client::theFinalReply = nullptr
privateinherited

adapted reply from ICAP or virgin reply

Definition at line 218 of file Client.h.

Referenced by Client::finalReply(), Client::haveParsedReplyHeaders(), Client::maybePurgeOthers(), Client::setFinalReply(), and Client::~Client().

◆ theSize

int64_t Ftp::Gateway::theSize

Definition at line 113 of file FtpGateway.cc.

Referenced by ftpFail(), ftpReadSize(), and ftpSendPassive().

◆ theVirginReply

HttpReply* Client::theVirginReply = nullptr
privateinherited

reply received from the origin server

Definition at line 217 of file Client.h.

Referenced by Client::setVirginReply(), Client::virginReply(), and Client::~Client().

◆ title_url

String Ftp::Gateway::title_url

Definition at line 108 of file FtpGateway.cc.

Referenced by ftpListDir(), and ftpReadSize().

◆ typecode

char Ftp::Gateway::typecode

Definition at line 122 of file FtpGateway.cc.

Referenced by ftpRestOrList(), and ftpSendType().

◆ typeName

◆ user

char Ftp::Gateway::user[MAX_URL]

Definition at line 102 of file FtpGateway.cc.

Referenced by ftpSendUser(), and Gateway().

◆ virginBodyDestination

◆ waitingForDelayAwareReadChance

bool Client::waitingForDelayAwareReadChance = false
protectedinherited

The documentation for this class was generated from the following file:

 

Introduction

Documentation

Support

Miscellaneous