| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877 | 
							- //---------------------------------------------------------------------------
 
- #include <vcl.h>
 
- #pragma hdrstop
 
- #include "Common.h"
 
- #include "Terminal.h"
 
- #include "Queue.h"
 
- #include "Exceptions.h"
 
- #include <System.DateUtils.hpp>
 
- //---------------------------------------------------------------------------
 
- #pragma package(smart_init)
 
- //---------------------------------------------------------------------------
 
- class TBackgroundTerminal;
 
- //---------------------------------------------------------------------------
 
- class TParallelTransferQueueItem : public TLocatedQueueItem
 
- {
 
- public:
 
-   __fastcall TParallelTransferQueueItem(const TLocatedQueueItem * ParentItem, TParallelOperation * ParallelOperation);
 
- protected:
 
-   virtual void __fastcall DoExecute(TTerminal * Terminal);
 
- private:
 
-   TParallelOperation * FParallelOperation;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TUserAction
 
- {
 
- public:
 
-   virtual __fastcall ~TUserAction() {}
 
-   virtual void __fastcall Execute(void * Arg) = 0;
 
-   virtual bool __fastcall Force() { return false; }
 
- };
 
- //---------------------------------------------------------------------------
 
- class TNotifyAction : public TUserAction
 
- {
 
- public:
 
-   TNotifyAction(TNotifyEvent AOnNotify) :
 
-     OnNotify(AOnNotify)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnNotify != NULL)
 
-     {
 
-       OnNotify(Sender);
 
-     }
 
-   }
 
-   TNotifyEvent OnNotify;
 
-   TObject * Sender;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TInformationUserAction : public TUserAction
 
- {
 
- public:
 
-   TInformationUserAction(TInformationEvent AOnInformation) :
 
-     OnInformation(AOnInformation)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnInformation != NULL)
 
-     {
 
-       OnInformation(Terminal, Str, Status, Phase);
 
-     }
 
-   }
 
-   virtual bool __fastcall Force()
 
-   {
 
-     // we need to propagate mainly the end-phase event even, when user cancels
 
-     // the connection, so that authentication window is closed
 
-     return TUserAction::Force() || (Phase >= 0);
 
-   }
 
-   TInformationEvent OnInformation;
 
-   TTerminal * Terminal;
 
-   UnicodeString Str;
 
-   bool Status;
 
-   int Phase;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TQueryUserAction : public TUserAction
 
- {
 
- public:
 
-   TQueryUserAction(TQueryUserEvent AOnQueryUser) :
 
-     OnQueryUser(AOnQueryUser)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnQueryUser != NULL)
 
-     {
 
-       OnQueryUser(Sender, Query, MoreMessages, Answers, Params, Answer, Type, Arg);
 
-     }
 
-   }
 
-   TQueryUserEvent OnQueryUser;
 
-   TObject * Sender;
 
-   UnicodeString Query;
 
-   TStrings * MoreMessages;
 
-   unsigned int Answers;
 
-   const TQueryParams * Params;
 
-   unsigned int Answer;
 
-   TQueryType Type;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TPromptUserAction : public TUserAction
 
- {
 
- public:
 
-   __fastcall TPromptUserAction(TPromptUserEvent AOnPromptUser) :
 
-     OnPromptUser(AOnPromptUser), Results(new TStringList())
 
-   {
 
-   }
 
-   virtual __fastcall ~TPromptUserAction()
 
-   {
 
-     delete Results;
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnPromptUser != NULL)
 
-     {
 
-       OnPromptUser(Terminal, Kind, Name, Instructions, Prompts, Results, Result, Arg);
 
-     }
 
-   }
 
-   TPromptUserEvent OnPromptUser;
 
-   TTerminal * Terminal;
 
-   TPromptKind Kind;
 
-   UnicodeString Name;
 
-   UnicodeString Instructions;
 
-   TStrings * Prompts;
 
-   TStrings * Results;
 
-   bool Result;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TShowExtendedExceptionAction : public TUserAction
 
- {
 
- public:
 
-   __fastcall TShowExtendedExceptionAction(TExtendedExceptionEvent AOnShowExtendedException) :
 
-     OnShowExtendedException(AOnShowExtendedException)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnShowExtendedException != NULL)
 
-     {
 
-       OnShowExtendedException(Terminal, E, Arg);
 
-     }
 
-   }
 
-   TExtendedExceptionEvent OnShowExtendedException;
 
-   TTerminal * Terminal;
 
-   Exception * E;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TDisplayBannerAction : public TUserAction
 
- {
 
- public:
 
-   __fastcall TDisplayBannerAction (TDisplayBannerEvent AOnDisplayBanner) :
 
-     OnDisplayBanner(AOnDisplayBanner)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnDisplayBanner != NULL)
 
-     {
 
-       OnDisplayBanner(Terminal, SessionName, Banner, NeverShowAgain, Options, Params);
 
-     }
 
-   }
 
-   TDisplayBannerEvent OnDisplayBanner;
 
-   TTerminal * Terminal;
 
-   UnicodeString SessionName;
 
-   UnicodeString Banner;
 
-   bool NeverShowAgain;
 
-   int Options;
 
-   unsigned int Params;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TReadDirectoryAction : public TUserAction
 
- {
 
- public:
 
-   TReadDirectoryAction(TReadDirectoryEvent AOnReadDirectory) :
 
-     OnReadDirectory(AOnReadDirectory)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnReadDirectory != NULL)
 
-     {
 
-       OnReadDirectory(Sender, ReloadOnly);
 
-     }
 
-   }
 
-   TReadDirectoryEvent OnReadDirectory;
 
-   TObject * Sender;
 
-   bool ReloadOnly;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TReadDirectoryProgressAction : public TUserAction
 
- {
 
- public:
 
-   TReadDirectoryProgressAction(TReadDirectoryProgressEvent AOnReadDirectoryProgress) :
 
-     OnReadDirectoryProgress(AOnReadDirectoryProgress)
 
-   {
 
-   }
 
-   virtual void __fastcall Execute(void * Arg)
 
-   {
 
-     if (OnReadDirectoryProgress != NULL)
 
-     {
 
-       OnReadDirectoryProgress(Sender, Progress, ResolvedLinks, Cancel);
 
-     }
 
-   }
 
-   TReadDirectoryProgressEvent OnReadDirectoryProgress;
 
-   TObject * Sender;
 
-   int Progress;
 
-   int ResolvedLinks;
 
-   bool Cancel;
 
- };
 
- //---------------------------------------------------------------------------
 
- class TTerminalItem : public TSignalThread
 
- {
 
- friend class TQueueItem;
 
- friend class TBackgroundTerminal;
 
- public:
 
-   __fastcall TTerminalItem(TTerminalQueue * Queue, int Index);
 
-   virtual __fastcall ~TTerminalItem();
 
-   void __fastcall Process(TQueueItem * Item);
 
-   bool __fastcall ProcessUserAction(void * Arg);
 
-   void __fastcall Cancel();
 
-   void __fastcall Idle();
 
-   bool __fastcall Pause();
 
-   bool __fastcall Resume();
 
- protected:
 
-   TTerminalQueue * FQueue;
 
-   TBackgroundTerminal * FTerminal;
 
-   TQueueItem * FItem;
 
-   TCriticalSection * FCriticalSection;
 
-   TUserAction * FUserAction;
 
-   bool FCancel;
 
-   bool FPause;
 
-   virtual void __fastcall ProcessEvent();
 
-   virtual bool __fastcall Finished();
 
-   bool __fastcall WaitForUserAction(TQueueItem::TStatus ItemStatus, TUserAction * UserAction);
 
-   bool __fastcall OverrideItemStatus(TQueueItem::TStatus & ItemStatus);
 
-   void __fastcall TerminalQueryUser(TObject * Sender,
 
-     const UnicodeString Query, TStrings * MoreMessages, unsigned int Answers,
 
-     const TQueryParams * Params, unsigned int & Answer, TQueryType Type, void * Arg);
 
-   void __fastcall TerminalPromptUser(TTerminal * Terminal, TPromptKind Kind,
 
-     UnicodeString Name, UnicodeString Instructions,
 
-     TStrings * Prompts, TStrings * Results, bool & Result, void * Arg);
 
-   void __fastcall TerminalShowExtendedException(TTerminal * Terminal,
 
-     Exception * E, void * Arg);
 
-   void __fastcall OperationFinished(TFileOperation Operation, TOperationSide Side,
 
-     bool Temp, const UnicodeString & FileName, bool Success,
 
-     TOnceDoneOperation & OnceDoneOperation);
 
-   void __fastcall OperationProgress(TFileOperationProgressType & ProgressData);
 
- };
 
- //---------------------------------------------------------------------------
 
- // TSignalThread
 
- //---------------------------------------------------------------------------
 
- int __fastcall TSimpleThread::ThreadProc(void * Thread)
 
- {
 
-   TSimpleThread * SimpleThread = reinterpret_cast<TSimpleThread*>(Thread);
 
-   DebugAssert(SimpleThread != NULL);
 
-   try
 
-   {
 
-     SimpleThread->Execute();
 
-   }
 
-   catch(...)
 
-   {
 
-     // we do not expect thread to be terminated with exception
 
-     DebugFail();
 
-   }
 
-   SimpleThread->FFinished = true;
 
-   if (SimpleThread->Finished())
 
-   {
 
-     delete SimpleThread;
 
-   }
 
-   return 0;
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TSimpleThread::TSimpleThread() :
 
-   FThread(NULL), FFinished(true)
 
- {
 
-   FThread = reinterpret_cast<HANDLE>(
 
-     StartThread(NULL, 0, ThreadProc, this, CREATE_SUSPENDED, FThreadId));
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TSimpleThread::~TSimpleThread()
 
- {
 
-   Close();
 
-   if (FThread != NULL)
 
-   {
 
-     CloseHandle(FThread);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TSimpleThread::IsFinished()
 
- {
 
-   return FFinished;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSimpleThread::Start()
 
- {
 
-   if (ResumeThread(FThread) == 1)
 
-   {
 
-     FFinished = false;
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TSimpleThread::Finished()
 
- {
 
-   return false;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSimpleThread::Close()
 
- {
 
-   if (!FFinished)
 
-   {
 
-     Terminate();
 
-     WaitFor();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSimpleThread::WaitFor(unsigned int Milliseconds)
 
- {
 
-   WaitForSingleObject(FThread, Milliseconds);
 
- }
 
- //---------------------------------------------------------------------------
 
- // TSignalThread
 
- //---------------------------------------------------------------------------
 
- __fastcall TSignalThread::TSignalThread(bool LowPriority, HANDLE Event) :
 
-   TSimpleThread(),
 
-   FTerminated(true), FEvent(NULL)
 
- {
 
-   if (Event == NULL)
 
-   {
 
-     FEvent = CreateEvent(NULL, false, false, NULL);
 
-   }
 
-   else
 
-   {
 
-     FEvent = Event;
 
-   }
 
-   DebugAssert(FEvent != NULL);
 
-   if (LowPriority)
 
-   {
 
-     ::SetThreadPriority(FThread, THREAD_PRIORITY_BELOW_NORMAL);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TSignalThread::~TSignalThread()
 
- {
 
-   // cannot leave closing to TSimpleThread as we need to close it before
 
-   // destroying the event
 
-   Close();
 
-   if (FEvent)
 
-   {
 
-     CloseHandle(FEvent);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSignalThread::Start()
 
- {
 
-   FTerminated = false;
 
-   TSimpleThread::Start();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSignalThread::TriggerEvent()
 
- {
 
-   SetEvent(FEvent);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TSignalThread::WaitForEvent()
 
- {
 
-   // should never return -1, so it is only about 0 or 1
 
-   return (WaitForEvent(INFINITE) > 0);
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TSignalThread::WaitForEvent(unsigned int Timeout)
 
- {
 
-   unsigned int Result = WaitForSingleObject(FEvent, Timeout);
 
-   int Return;
 
-   if ((Result == WAIT_TIMEOUT) && !FTerminated)
 
-   {
 
-     Return = -1;
 
-   }
 
-   else
 
-   {
 
-     Return = ((Result == WAIT_OBJECT_0) && !FTerminated) ? 1 : 0;
 
-   }
 
-   return Return;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSignalThread::Execute()
 
- {
 
-   while (!FTerminated)
 
-   {
 
-     if (WaitForEvent())
 
-     {
 
-       ProcessEvent();
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TSignalThread::Terminate()
 
- {
 
-   FTerminated = true;
 
-   TriggerEvent();
 
- }
 
- //---------------------------------------------------------------------------
 
- // TTerminalQueue
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalQueue::TTerminalQueue(TTerminal * Terminal,
 
-   TConfiguration * Configuration) :
 
-   TSignalThread(true),
 
-   FTerminal(Terminal), FTransfersLimit(2), FKeepDoneItemsFor(0), FEnabled(true),
 
-   FConfiguration(Configuration), FSessionData(NULL), FItems(NULL), FDoneItems(NULL),
 
-   FTerminals(NULL), FItemsSection(NULL), FFreeTerminals(0),
 
-   FItemsInProcess(0), FTemporaryTerminals(0), FOverallTerminals(0)
 
- {
 
-   FOnQueryUser = NULL;
 
-   FOnPromptUser = NULL;
 
-   FOnShowExtendedException = NULL;
 
-   FOnQueueItemUpdate = NULL;
 
-   FOnListUpdate = NULL;
 
-   FOnEvent = NULL;
 
-   FLastIdle = Now();
 
-   FIdleInterval = EncodeTimeVerbose(0, 0, 2, 0);
 
-   DebugAssert(Terminal != NULL);
 
-   FSessionData = new TSessionData(L"");
 
-   FSessionData->Assign(Terminal->SessionData);
 
-   FItems = new TList();
 
-   FDoneItems = new TList();
 
-   FTerminals = new TList();
 
-   FForcedItems = new TList();
 
-   FItemsSection = new TCriticalSection();
 
-   Start();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalQueue::~TTerminalQueue()
 
- {
 
-   Close();
 
-   {
 
-     TGuard Guard(FItemsSection);
 
-     TTerminalItem * TerminalItem;
 
-     while (FTerminals->Count > 0)
 
-     {
 
-       TerminalItem = reinterpret_cast<TTerminalItem*>(FTerminals->Items[0]);
 
-       FTerminals->Delete(0);
 
-       TerminalItem->Terminate();
 
-       TerminalItem->WaitFor();
 
-       delete TerminalItem;
 
-     }
 
-     delete FTerminals;
 
-     delete FForcedItems;
 
-     FreeItemsList(FItems);
 
-     FreeItemsList(FDoneItems);
 
-   }
 
-   delete FItemsSection;
 
-   delete FSessionData;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::FreeItemsList(TList * List)
 
- {
 
-   for (int Index = 0; Index < List->Count; Index++)
 
-   {
 
-     delete GetItem(List, Index);
 
-   }
 
-   delete List;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::TerminalFinished(TTerminalItem * TerminalItem)
 
- {
 
-   if (!FTerminated)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FTerminals->IndexOf(TerminalItem);
 
-       DebugAssert(Index >= 0);
 
-       if (Index < FFreeTerminals)
 
-       {
 
-         FFreeTerminals--;
 
-       }
 
-       // Index may be >= FTransfersLimit also when the transfer limit was
 
-       // recently decreased, then
 
-       // FTemporaryTerminals < FTerminals->Count - FTransfersLimit
 
-       if ((FTransfersLimit >= 0) && (Index >= FTransfersLimit) && (FTemporaryTerminals > 0))
 
-       {
 
-         FTemporaryTerminals--;
 
-       }
 
-       FTerminals->Extract(TerminalItem);
 
-       delete TerminalItem;
 
-     }
 
-     TriggerEvent();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::TerminalFree(TTerminalItem * TerminalItem)
 
- {
 
-   bool Result = true;
 
-   if (!FTerminated)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FTerminals->IndexOf(TerminalItem);
 
-       DebugAssert(Index >= 0);
 
-       DebugAssert(Index >= FFreeTerminals);
 
-       Result = (FTransfersLimit < 0) || (Index < FTransfersLimit);
 
-       if (Result)
 
-       {
 
-         FTerminals->Move(Index, 0);
 
-         FFreeTerminals++;
 
-       }
 
-     }
 
-     TriggerEvent();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueue::GetParallelDurationThreshold()
 
- {
 
-   return FConfiguration->ParallelDurationThreshold;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::AddItem(TQueueItem * Item)
 
- {
 
-   DebugAssert(!FTerminated);
 
-   Item->SetStatus(TQueueItem::qsPending);
 
-   {
 
-     TGuard Guard(FItemsSection);
 
-     FItems->Add(Item);
 
-     Item->FQueue = this;
 
-   }
 
-   DoListUpdate();
 
-   TriggerEvent();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::RetryItem(TQueueItem * Item)
 
- {
 
-   if (!FTerminated)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FItems->Remove(Item);
 
-       DebugAssert(Index < FItemsInProcess);
 
-       DebugUsedParam(Index);
 
-       FItemsInProcess--;
 
-       FItems->Add(Item);
 
-     }
 
-     DoListUpdate();
 
-     TriggerEvent();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::DeleteItem(TQueueItem * Item, bool CanKeep)
 
- {
 
-   if (!FTerminated)
 
-   {
 
-     bool Empty;
 
-     bool EmptyButMonitored;
 
-     bool Monitored;
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       // does this need to be within guard?
 
-       Monitored = (Item->CompleteEvent != INVALID_HANDLE_VALUE);
 
-       int Index = FItems->Remove(Item);
 
-       DebugAssert(Index < FItemsInProcess);
 
-       DebugUsedParam(Index);
 
-       FItemsInProcess--;
 
-       FForcedItems->Remove(Item);
 
-       // =0  do not keep
 
-       // <0  infinity
 
-       if ((FKeepDoneItemsFor != 0) && CanKeep && Item->Complete())
 
-       {
 
-         DebugAssert(Item->Status == TQueueItem::qsDone);
 
-         FDoneItems->Add(Item);
 
-       }
 
-       else
 
-       {
 
-         delete Item;
 
-       }
 
-       EmptyButMonitored = true;
 
-       Index = 0;
 
-       while (EmptyButMonitored && (Index < FItems->Count))
 
-       {
 
-         EmptyButMonitored = (GetItem(FItems, Index)->CompleteEvent != INVALID_HANDLE_VALUE);
 
-         Index++;
 
-       }
 
-       Empty = (FItems->Count == 0);
 
-     }
 
-     DoListUpdate();
 
-     // report empty but/except for monitored, if queue is empty or only monitored items are pending.
 
-     // do not report if current item was the last, but was monitored.
 
-     if (!Monitored && EmptyButMonitored)
 
-     {
 
-       DoEvent(qeEmptyButMonitored);
 
-     }
 
-     if (Empty)
 
-     {
 
-       DoEvent(qeEmpty);
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItem * __fastcall TTerminalQueue::GetItem(TList * List, int Index)
 
- {
 
-   return reinterpret_cast<TQueueItem*>(List->Items[Index]);
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItem * __fastcall TTerminalQueue::GetItem(int Index)
 
- {
 
-   return GetItem(FItems, Index);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::UpdateStatusForList(
 
-   TTerminalQueueStatus * Status, TList * List, TTerminalQueueStatus * Current)
 
- {
 
-   TQueueItem * Item;
 
-   TQueueItemProxy * ItemProxy;
 
-   for (int Index = 0; Index < List->Count; Index++)
 
-   {
 
-     Item = GetItem(List, Index);
 
-     if (Current != NULL)
 
-     {
 
-       ItemProxy = Current->FindByQueueItem(Item);
 
-     }
 
-     else
 
-     {
 
-       ItemProxy = NULL;
 
-     }
 
-     if (ItemProxy != NULL)
 
-     {
 
-       Current->Delete(ItemProxy);
 
-       Status->Add(ItemProxy);
 
-       ItemProxy->Update();
 
-     }
 
-     else
 
-     {
 
-       Status->Add(new TQueueItemProxy(this, Item));
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- TTerminalQueueStatus * __fastcall TTerminalQueue::CreateStatus(TTerminalQueueStatus * Current)
 
- {
 
-   TTerminalQueueStatus * Status = new TTerminalQueueStatus();
 
-   try
 
-   {
 
-     try
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       UpdateStatusForList(Status, FDoneItems, Current);
 
-       Status->SetDoneCount(Status->Count);
 
-       UpdateStatusForList(Status, FItems, Current);
 
-     }
 
-     __finally
 
-     {
 
-       if (Current != NULL)
 
-       {
 
-         delete Current;
 
-       }
 
-     }
 
-   }
 
-   catch(...)
 
-   {
 
-     delete Status;
 
-     throw;
 
-   }
 
-   return Status;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemGetData(TQueueItem * Item,
 
-   TQueueItemProxy * Proxy)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     TGuard Guard(FItemsSection);
 
-     Result = (FDoneItems->IndexOf(Item) >= 0) || (FItems->IndexOf(Item) >= 0);
 
-     if (Result)
 
-     {
 
-       Item->GetData(Proxy);
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemProcessUserAction(TQueueItem * Item, void * Arg)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     TTerminalItem * TerminalItem;
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       Result = (FItems->IndexOf(Item) >= 0) &&
 
-         TQueueItem::IsUserActionStatus(Item->Status);
 
-       if (Result)
 
-       {
 
-         TerminalItem = Item->FTerminalItem;
 
-       }
 
-     }
 
-     if (Result)
 
-     {
 
-       Result = TerminalItem->ProcessUserAction(Arg);
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemMove(TQueueItem * Item, TQueueItem * BeforeItem)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FItems->IndexOf(Item);
 
-       int IndexDest = FItems->IndexOf(BeforeItem);
 
-       Result = (Index >= 0) && (IndexDest >= 0) &&
 
-         (Item->GetStatus() == TQueueItem::qsPending) &&
 
-         (BeforeItem->GetStatus() == TQueueItem::qsPending);
 
-       if (Result)
 
-       {
 
-         FItems->Move(Index, IndexDest);
 
-       }
 
-     }
 
-     if (Result)
 
-     {
 
-       DoListUpdate();
 
-       TriggerEvent();
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemExecuteNow(TQueueItem * Item)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FItems->IndexOf(Item);
 
-       Result = (Index >= 0) && (Item->GetStatus() == TQueueItem::qsPending) &&
 
-         // prevent double-initiation when "execute" is clicked twice too fast
 
-         (Index >= FItemsInProcess);
 
-       if (Result)
 
-       {
 
-         if (Index > FItemsInProcess)
 
-         {
 
-           FItems->Move(Index, FItemsInProcess);
 
-         }
 
-         if ((FTransfersLimit >= 0) && (FTerminals->Count >= FTransfersLimit) &&
 
-             // when queue is disabled, we may have idle terminals,
 
-             // even when there are pending queue items
 
-             (FFreeTerminals == 0))
 
-         {
 
-           FTemporaryTerminals++;
 
-         }
 
-         FForcedItems->Add(Item);
 
-       }
 
-     }
 
-     if (Result)
 
-     {
 
-       DoListUpdate();
 
-       TriggerEvent();
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemDelete(TQueueItem * Item)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     bool UpdateList = false;
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       int Index = FItems->IndexOf(Item);
 
-       Result = (Index >= 0);
 
-       if (Result)
 
-       {
 
-         if (Item->Status == TQueueItem::qsPending)
 
-         {
 
-           FItems->Delete(Index);
 
-           FForcedItems->Remove(Item);
 
-           delete Item;
 
-           UpdateList = true;
 
-         }
 
-         else
 
-         {
 
-           Item->FTerminalItem->Cancel();
 
-         }
 
-       }
 
-       else
 
-       {
 
-         Index = FDoneItems->IndexOf(Item);
 
-         Result = (Index >= 0);
 
-         if (Result)
 
-         {
 
-           FDoneItems->Delete(Index);
 
-           UpdateList = true;
 
-         }
 
-       }
 
-     }
 
-     if (UpdateList)
 
-     {
 
-       DoListUpdate();
 
-       TriggerEvent();
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemPause(TQueueItem * Item, bool Pause)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     TTerminalItem * TerminalItem;
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       Result = (FItems->IndexOf(Item) >= 0) &&
 
-         ((Pause && (Item->Status == TQueueItem::qsProcessing)) ||
 
-          (!Pause && (Item->Status == TQueueItem::qsPaused)));
 
-       if (Result)
 
-       {
 
-         TerminalItem = Item->FTerminalItem;
 
-       }
 
-     }
 
-     if (Result)
 
-     {
 
-       if (Pause)
 
-       {
 
-         Result = TerminalItem->Pause();
 
-       }
 
-       else
 
-       {
 
-         Result = TerminalItem->Resume();
 
-       }
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemSetCPSLimit(TQueueItem * Item, unsigned long CPSLimit)
 
- {
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     TGuard Guard(FItemsSection);
 
-     Result = (FItems->IndexOf(Item) >= 0);
 
-     if (Result)
 
-     {
 
-       Item->SetCPSLimit(CPSLimit);
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ItemGetCPSLimit(TQueueItem * Item, unsigned long & CPSLimit)
 
- {
 
-   CPSLimit = 0;
 
-   // to prevent deadlocks when closing queue from other thread
 
-   bool Result = !FFinished;
 
-   if (Result)
 
-   {
 
-     TGuard Guard(FItemsSection);
 
-     Result = (FItems->IndexOf(Item) >= 0);
 
-     if (Result)
 
-     {
 
-       CPSLimit = Item->GetCPSLimit();
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::Idle()
 
- {
 
-   TDateTime N = Now();
 
-   if (N - FLastIdle > FIdleInterval)
 
-   {
 
-     FLastIdle = N;
 
-     TTerminalItem * TerminalItem = NULL;
 
-     if (FFreeTerminals > 0)
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       if (FFreeTerminals > 0)
 
-       {
 
-         // take the last free terminal, because TerminalFree() puts it to the
 
-         // front, this ensures we cycle thru all free terminals
 
-         TerminalItem = reinterpret_cast<TTerminalItem*>(FTerminals->Items[FFreeTerminals - 1]);
 
-         FTerminals->Move(FFreeTerminals - 1, FTerminals->Count - 1);
 
-         FFreeTerminals--;
 
-       }
 
-     }
 
-     if (TerminalItem != NULL)
 
-     {
 
-       TerminalItem->Idle();
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::WaitForEvent()
 
- {
 
-   // terminate loop regularly, so that we can check for expired done items
 
-   bool Result = (TSignalThread::WaitForEvent(1000) != 0);
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::ProcessEvent()
 
- {
 
-   TTerminalItem * TerminalItem;
 
-   TQueueItem * Item;
 
-   do
 
-   {
 
-     TerminalItem = NULL;
 
-     Item = NULL;
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       // =0  do not keep
 
-       // <0  infinity
 
-       if (FKeepDoneItemsFor >= 0)
 
-       {
 
-         TDateTime RemoveDoneItemsBefore = Now();
 
-         if (FKeepDoneItemsFor > 0)
 
-         {
 
-           RemoveDoneItemsBefore = IncSecond(RemoveDoneItemsBefore, -FKeepDoneItemsFor);
 
-         }
 
-         for (int Index = 0; Index < FDoneItems->Count; Index++)
 
-         {
 
-           TQueueItem * Item = GetItem(FDoneItems, Index);
 
-           if (Item->FDoneAt <= RemoveDoneItemsBefore)
 
-           {
 
-             FDoneItems->Delete(Index);
 
-             delete Item;
 
-             Index--;
 
-             DoListUpdate();
 
-           }
 
-         }
 
-       }
 
-       if (FItems->Count > FItemsInProcess)
 
-       {
 
-         Item = GetItem(FItemsInProcess);
 
-         int ForcedIndex = FForcedItems->IndexOf(Item);
 
-         if (FEnabled || (ForcedIndex >= 0))
 
-         {
 
-           if ((FFreeTerminals == 0) &&
 
-               ((FTransfersLimit < 0) ||
 
-                (FTerminals->Count < FTransfersLimit + FTemporaryTerminals)))
 
-           {
 
-             FOverallTerminals++;
 
-             TerminalItem = new TTerminalItem(this, FOverallTerminals);
 
-             FTerminals->Add(TerminalItem);
 
-           }
 
-           else if (FFreeTerminals > 0)
 
-           {
 
-             TerminalItem = reinterpret_cast<TTerminalItem*>(FTerminals->Items[0]);
 
-             FTerminals->Move(0, FTerminals->Count - 1);
 
-             FFreeTerminals--;
 
-           }
 
-           if (TerminalItem != NULL)
 
-           {
 
-             if (ForcedIndex >= 0)
 
-             {
 
-               FForcedItems->Delete(ForcedIndex);
 
-             }
 
-             FItemsInProcess++;
 
-           }
 
-         }
 
-       }
 
-     }
 
-     if (TerminalItem != NULL)
 
-     {
 
-       TerminalItem->Process(Item);
 
-     }
 
-   }
 
-   while (!FTerminated && (TerminalItem != NULL));
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::DoQueueItemUpdate(TQueueItem * Item)
 
- {
 
-   if (OnQueueItemUpdate != NULL)
 
-   {
 
-     OnQueueItemUpdate(this, Item);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::DoListUpdate()
 
- {
 
-   if (OnListUpdate != NULL)
 
-   {
 
-     OnListUpdate(this);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::DoEvent(TQueueEvent Event)
 
- {
 
-   if (OnEvent != NULL)
 
-   {
 
-     OnEvent(this, Event);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::SetTransfersLimit(int value)
 
- {
 
-   if (FTransfersLimit != value)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       if ((value >= 0) && (value < FItemsInProcess))
 
-       {
 
-         FTemporaryTerminals = (FItemsInProcess - value);
 
-       }
 
-       else
 
-       {
 
-         FTemporaryTerminals = 0;
 
-       }
 
-       FTransfersLimit = value;
 
-     }
 
-     TriggerEvent();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::SetKeepDoneItemsFor(int value)
 
- {
 
-   if (FKeepDoneItemsFor != value)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       FKeepDoneItemsFor = value;
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueue::SetEnabled(bool value)
 
- {
 
-   if (FEnabled != value)
 
-   {
 
-     {
 
-       TGuard Guard(FItemsSection);
 
-       FEnabled = value;
 
-     }
 
-     TriggerEvent();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::GetIsEmpty()
 
- {
 
-   TGuard Guard(FItemsSection);
 
-   return (FItems->Count == 0);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::TryAddParallelOperation(TQueueItem * Item, bool Force)
 
- {
 
-   TGuard Guard(FItemsSection);
 
-   bool Result =
 
-     (FFreeTerminals > 0) ||
 
-     (Force && (FItemsInProcess < FTransfersLimit));
 
-   if (Result)
 
-   {
 
-     TQueueItem * ParallelItem = DebugNotNull(Item->CreateParallelOperation());
 
-     if (!FEnabled)
 
-     {
 
-       FForcedItems->Add(ParallelItem);
 
-     }
 
-     AddItem(ParallelItem);
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueue::ContinueParallelOperation()
 
- {
 
-   TGuard Guard(FItemsSection);
 
-   return (FItems->Count <= FItemsInProcess);
 
- }
 
- //---------------------------------------------------------------------------
 
- // TBackgroundItem
 
- //---------------------------------------------------------------------------
 
- class TBackgroundTerminal : public TSecondaryTerminal
 
- {
 
- friend class TTerminalItem;
 
- public:
 
-   __fastcall TBackgroundTerminal(TTerminal * MainTerminal,
 
-     TSessionData * SessionData, TConfiguration * Configuration,
 
-     TTerminalItem * Item, const UnicodeString & Name);
 
- protected:
 
-   virtual bool __fastcall DoQueryReopen(Exception * E);
 
- private:
 
-   TTerminalItem * FItem;
 
- };
 
- //---------------------------------------------------------------------------
 
- __fastcall TBackgroundTerminal::TBackgroundTerminal(TTerminal * MainTerminal,
 
-     TSessionData * SessionData, TConfiguration * Configuration, TTerminalItem * Item,
 
-     const UnicodeString & Name) :
 
-   TSecondaryTerminal(MainTerminal, SessionData, Configuration, Name), FItem(Item)
 
- {
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TBackgroundTerminal::DoQueryReopen(Exception * /*E*/)
 
- {
 
-   bool Result;
 
-   if (FItem->FTerminated || FItem->FCancel)
 
-   {
 
-     // avoid reconnection if we are closing
 
-     Result = false;
 
-   }
 
-   else
 
-   {
 
-     Sleep(Configuration->SessionReopenBackground);
 
-     Result = true;
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TTerminalItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalItem::TTerminalItem(TTerminalQueue * Queue, int Index) :
 
-   TSignalThread(true), FQueue(Queue), FTerminal(NULL), FItem(NULL),
 
-   FCriticalSection(NULL), FUserAction(NULL)
 
- {
 
-   FCriticalSection = new TCriticalSection();
 
-   FTerminal = new TBackgroundTerminal(FQueue->FTerminal, Queue->FSessionData,
 
-     FQueue->FConfiguration, this, FORMAT(L"Background %d", (Index)));
 
-   try
 
-   {
 
-     FTerminal->UseBusyCursor = false;
 
-     FTerminal->OnQueryUser = TerminalQueryUser;
 
-     FTerminal->OnPromptUser = TerminalPromptUser;
 
-     FTerminal->OnShowExtendedException = TerminalShowExtendedException;
 
-     FTerminal->OnProgress = OperationProgress;
 
-     FTerminal->OnFinished = OperationFinished;
 
-   }
 
-   catch(...)
 
-   {
 
-     delete FTerminal;
 
-     throw;
 
-   }
 
-   Start();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalItem::~TTerminalItem()
 
- {
 
-   Close();
 
-   DebugAssert(FItem == NULL);
 
-   delete FTerminal;
 
-   delete FCriticalSection;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::Process(TQueueItem * Item)
 
- {
 
-   {
 
-     TGuard Guard(FCriticalSection);
 
-     DebugAssert(FItem == NULL);
 
-     FItem = Item;
 
-   }
 
-   TriggerEvent();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::ProcessEvent()
 
- {
 
-   TGuard Guard(FCriticalSection);
 
-   bool Retry = true;
 
-   FCancel = false;
 
-   FPause = false;
 
-   FItem->FTerminalItem = this;
 
-   try
 
-   {
 
-     DebugAssert(FItem != NULL);
 
-     if (!FTerminal->Active)
 
-     {
 
-       FItem->SetStatus(TQueueItem::qsConnecting);
 
-       FTerminal->SessionData->RemoteDirectory = FItem->StartupDirectory();
 
-       FTerminal->Open();
 
-     }
 
-     Retry = false;
 
-     if (!FCancel)
 
-     {
 
-       FTerminal->UpdateFromMain();
 
-       FItem->SetStatus(TQueueItem::qsProcessing);
 
-       FItem->Execute(this);
 
-     }
 
-   }
 
-   catch(Exception & E)
 
-   {
 
-     UnicodeString Message;
 
-     if (ExceptionMessageFormatted(&E, Message))
 
-     {
 
-       // do not show error messages, if task was cancelled anyway
 
-       // (for example if transfer is cancelled during reconnection attempts)
 
-       if (!FCancel &&
 
-           (FTerminal->QueryUserException(L"", &E, qaOK | qaCancel, NULL, qtError) == qaCancel))
 
-       {
 
-         FCancel = true;
 
-       }
 
-     }
 
-   }
 
-   FItem->SetStatus(TQueueItem::qsDone);
 
-   FItem->FTerminalItem = NULL;
 
-   TQueueItem * Item = FItem;
 
-   FItem = NULL;
 
-   if (Retry && !FCancel)
 
-   {
 
-     FQueue->RetryItem(Item);
 
-   }
 
-   else
 
-   {
 
-     FQueue->DeleteItem(Item, !FCancel);
 
-   }
 
-   if (!FTerminal->Active ||
 
-       !FQueue->TerminalFree(this))
 
-   {
 
-     Terminate();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::Idle()
 
- {
 
-   TGuard Guard(FCriticalSection);
 
-   DebugAssert(FTerminal->Active);
 
-   try
 
-   {
 
-     FTerminal->Idle();
 
-   }
 
-   catch(...)
 
-   {
 
-   }
 
-   if (!FTerminal->Active ||
 
-       !FQueue->TerminalFree(this))
 
-   {
 
-     Terminate();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::Cancel()
 
- {
 
-   FCancel = true;
 
-   if ((FItem->GetStatus() == TQueueItem::qsPaused) ||
 
-       TQueueItem::IsUserActionStatus(FItem->GetStatus()))
 
-   {
 
-     TriggerEvent();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::Pause()
 
- {
 
-   DebugAssert(FItem != NULL);
 
-   bool Result = (FItem->GetStatus() == TQueueItem::qsProcessing) && !FPause;
 
-   if (Result)
 
-   {
 
-     FPause = true;
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::Resume()
 
- {
 
-   DebugAssert(FItem != NULL);
 
-   bool Result = (FItem->GetStatus() == TQueueItem::qsPaused);
 
-   if (Result)
 
-   {
 
-     TriggerEvent();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::ProcessUserAction(void * Arg)
 
- {
 
-   // When status is changed twice quickly, the controller when responding
 
-   // to the first change (non-user-action) can be so slow to check only after
 
-   // the second (user-action) change occurs. Thus it responds it.
 
-   // Then as reaction to the second (user-action) change there will not be
 
-   // any outstanding user-action.
 
-   bool Result = (FUserAction != NULL);
 
-   if (Result)
 
-   {
 
-     DebugAssert(FItem != NULL);
 
-     FUserAction->Execute(Arg);
 
-     FUserAction = NULL;
 
-     TriggerEvent();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::WaitForUserAction(
 
-   TQueueItem::TStatus ItemStatus, TUserAction * UserAction)
 
- {
 
-   DebugAssert(FItem != NULL);
 
-   DebugAssert((FItem->GetStatus() == TQueueItem::qsProcessing) ||
 
-     (FItem->GetStatus() == TQueueItem::qsConnecting));
 
-   bool Result;
 
-   TQueueItem::TStatus PrevStatus = FItem->GetStatus();
 
-   try
 
-   {
 
-     FUserAction = UserAction;
 
-     FItem->SetStatus(ItemStatus);
 
-     FQueue->DoEvent(qePendingUserAction);
 
-     Result = !FTerminated && WaitForEvent() && !FCancel;
 
-   }
 
-   __finally
 
-   {
 
-     FUserAction = NULL;
 
-     FItem->SetStatus(PrevStatus);
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::Finished()
 
- {
 
-   bool Result = TSignalThread::Finished();
 
-   FQueue->TerminalFinished(this);
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::TerminalQueryUser(TObject * Sender,
 
-   const UnicodeString Query, TStrings * MoreMessages, unsigned int Answers,
 
-   const TQueryParams * Params, unsigned int & Answer, TQueryType Type, void * Arg)
 
- {
 
-   // so far query without queue item can occur only for key confirmation
 
-   // on re-key with non-cached host key. make it fail.
 
-   if (FItem != NULL)
 
-   {
 
-     DebugUsedParam(Arg);
 
-     DebugAssert(Arg == NULL);
 
-     TQueryUserAction Action(FQueue->OnQueryUser);
 
-     Action.Sender = Sender;
 
-     Action.Query = Query;
 
-     Action.MoreMessages = MoreMessages;
 
-     Action.Answers = Answers;
 
-     Action.Params = Params;
 
-     Action.Answer = Answer;
 
-     Action.Type = Type;
 
-     // if the query is "error", present it as an "error" state in UI,
 
-     // however it is still handled as query by the action.
 
-     TQueueItem::TStatus ItemStatus =
 
-       (Action.Type == qtError ? TQueueItem::qsError : TQueueItem::qsQuery);
 
-     if (WaitForUserAction(ItemStatus, &Action))
 
-     {
 
-       Answer = Action.Answer;
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::TerminalPromptUser(TTerminal * Terminal,
 
-   TPromptKind Kind, UnicodeString Name, UnicodeString Instructions, TStrings * Prompts,
 
-   TStrings * Results, bool & Result, void * Arg)
 
- {
 
-   if (FItem == NULL)
 
-   {
 
-     // sanity, should not occur
 
-     DebugFail();
 
-     Result = false;
 
-   }
 
-   else
 
-   {
 
-     DebugUsedParam(Arg);
 
-     DebugAssert(Arg == NULL);
 
-     TPromptUserAction Action(FQueue->OnPromptUser);
 
-     Action.Terminal = Terminal;
 
-     Action.Kind = Kind;
 
-     Action.Name = Name;
 
-     Action.Instructions = Instructions;
 
-     Action.Prompts = Prompts;
 
-     Action.Results->AddStrings(Results);
 
-     if (WaitForUserAction(TQueueItem::qsPrompt, &Action))
 
-     {
 
-       Results->Clear();
 
-       Results->AddStrings(Action.Results);
 
-       Result = Action.Result;
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::TerminalShowExtendedException(
 
-   TTerminal * Terminal, Exception * E, void * Arg)
 
- {
 
-   DebugUsedParam(Arg);
 
-   DebugAssert(Arg == NULL);
 
-   if ((FItem != NULL) &&
 
-       ShouldDisplayException(E))
 
-   {
 
-     TShowExtendedExceptionAction Action(FQueue->OnShowExtendedException);
 
-     Action.Terminal = Terminal;
 
-     Action.E = E;
 
-     WaitForUserAction(TQueueItem::qsError, &Action);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::OperationFinished(TFileOperation /*Operation*/,
 
-   TOperationSide /*Side*/, bool /*Temp*/, const UnicodeString & /*FileName*/,
 
-   bool /*Success*/, TOnceDoneOperation & /*OnceDoneOperation*/)
 
- {
 
-   // nothing
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalItem::OperationProgress(
 
-   TFileOperationProgressType & ProgressData)
 
- {
 
-   if (FPause && !FTerminated && !FCancel)
 
-   {
 
-     DebugAssert(FItem != NULL);
 
-     TQueueItem::TStatus PrevStatus = FItem->GetStatus();
 
-     DebugAssert(PrevStatus == TQueueItem::qsProcessing);
 
-     // must be set before TFileOperationProgressType::Suspend(), because
 
-     // it invokes this method back
 
-     FPause = false;
 
-     ProgressData.Suspend();
 
-     try
 
-     {
 
-       FItem->SetStatus(TQueueItem::qsPaused);
 
-       WaitForEvent();
 
-     }
 
-     __finally
 
-     {
 
-       FItem->SetStatus(PrevStatus);
 
-       ProgressData.Resume();
 
-     }
 
-   }
 
-   if (FTerminated || FCancel)
 
-   {
 
-     if (ProgressData.TransferringFile)
 
-     {
 
-       ProgressData.SetCancel(csCancelTransfer);
 
-     }
 
-     else
 
-     {
 
-       ProgressData.SetCancel(csCancel);
 
-     }
 
-   }
 
-   DebugAssert(FItem != NULL);
 
-   FItem->SetProgress(ProgressData);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalItem::OverrideItemStatus(TQueueItem::TStatus & ItemStatus)
 
- {
 
-   DebugAssert(FTerminal != NULL);
 
-   bool Result = (FTerminal->Status < ssOpened) && (ItemStatus == TQueueItem::qsProcessing);
 
-   if (Result)
 
-   {
 
-     ItemStatus = TQueueItem::qsConnecting;
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TQueueItem::TQueueItem() :
 
-   FStatus(qsPending), FTerminalItem(NULL), FSection(NULL), FProgressData(NULL),
 
-   FQueue(NULL), FInfo(NULL), FCompleteEvent(INVALID_HANDLE_VALUE),
 
-   FCPSLimit(-1)
 
- {
 
-   FSection = new TCriticalSection();
 
-   FInfo = new TInfo();
 
-   FInfo->SingleFile = false;
 
-   FInfo->Primary = true;
 
-   FInfo->GroupToken = this;
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TQueueItem::~TQueueItem()
 
- {
 
-   // we need to keep the total transfer size even after transfer completes
 
-   delete FProgressData;
 
-   Complete();
 
-   delete FSection;
 
-   delete FInfo;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItem::Complete()
 
- {
 
-   TGuard Guard(FSection);
 
-   if (FCompleteEvent != INVALID_HANDLE_VALUE)
 
-   {
 
-     SetEvent(FCompleteEvent);
 
-     FCompleteEvent = INVALID_HANDLE_VALUE;
 
-   }
 
-   return FInfo->Primary;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItem::IsUserActionStatus(TStatus Status)
 
- {
 
-   return (Status == qsQuery) || (Status == qsError) || (Status == qsPrompt);
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItem::TStatus __fastcall TQueueItem::GetStatus()
 
- {
 
-   TGuard Guard(FSection);
 
-   return FStatus;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::SetStatus(TStatus Status)
 
- {
 
-   {
 
-     TGuard Guard(FSection);
 
-     FStatus = Status;
 
-     if (FStatus == qsDone)
 
-     {
 
-       FDoneAt = Now();
 
-     }
 
-   }
 
-   DebugAssert((FQueue != NULL) || (Status == qsPending));
 
-   if (FQueue != NULL)
 
-   {
 
-     FQueue->DoQueueItemUpdate(this);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::ProgressUpdated()
 
- {
 
-   // noop
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::SetProgress(
 
-   TFileOperationProgressType & ProgressData)
 
- {
 
-   {
 
-     TGuard Guard(FSection);
 
-     // do not lose CPS limit override on "calculate size" operation,
 
-     // wait until the real transfer operation starts
 
-     if ((FCPSLimit >= 0) && ((ProgressData.Operation == foMove) || (ProgressData.Operation == foCopy)))
 
-     {
 
-       ProgressData.SetCPSLimit(static_cast<unsigned long>(FCPSLimit));
 
-       FCPSLimit = -1;
 
-     }
 
-     DebugAssert(FProgressData != NULL);
 
-     FProgressData->Assign(ProgressData);
 
-     FProgressData->Reset();
 
-   }
 
-   ProgressUpdated();
 
-   FQueue->DoQueueItemUpdate(this);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::GetData(TQueueItemProxy * Proxy)
 
- {
 
-   TGuard Guard(FSection);
 
-   DebugAssert(Proxy->FProgressData != NULL);
 
-   if (FProgressData != NULL)
 
-   {
 
-     Proxy->FProgressData->Assign(*FProgressData);
 
-   }
 
-   else
 
-   {
 
-     Proxy->FProgressData->Clear();
 
-   }
 
-   *Proxy->FInfo = *FInfo;
 
-   Proxy->FStatus = FStatus;
 
-   if (FTerminalItem != NULL)
 
-   {
 
-     FTerminalItem->OverrideItemStatus(Proxy->FStatus);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::Execute(TTerminalItem * TerminalItem)
 
- {
 
-   {
 
-     DebugAssert(FProgressData == NULL);
 
-     TGuard Guard(FSection);
 
-     FProgressData = new TFileOperationProgressType();
 
-   }
 
-   DoExecute(TerminalItem->FTerminal);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TQueueItem::SetCPSLimit(unsigned long CPSLimit)
 
- {
 
-   FCPSLimit = static_cast<long>(CPSLimit);
 
- }
 
- //---------------------------------------------------------------------------
 
- unsigned long __fastcall TQueueItem::DefaultCPSLimit()
 
- {
 
-   return 0;
 
- }
 
- //---------------------------------------------------------------------------
 
- unsigned long __fastcall TQueueItem::GetCPSLimit()
 
- {
 
-   unsigned long Result;
 
-   if (FCPSLimit >= 0)
 
-   {
 
-     Result = FCPSLimit;
 
-   }
 
-   else if (FProgressData != NULL)
 
-   {
 
-     Result = FProgressData->CPSLimit;
 
-   }
 
-   else
 
-   {
 
-     Result = DefaultCPSLimit();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItem * __fastcall TQueueItem::CreateParallelOperation()
 
- {
 
-   return NULL;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TQueueItemProxy
 
- //---------------------------------------------------------------------------
 
- __fastcall TQueueItemProxy::TQueueItemProxy(TTerminalQueue * Queue,
 
-   TQueueItem * QueueItem) :
 
-   FQueue(Queue), FQueueItem(QueueItem), FProgressData(NULL),
 
-   FQueueStatus(NULL), FInfo(NULL),
 
-   FProcessingUserAction(false), FUserData(NULL)
 
- {
 
-   FProgressData = new TFileOperationProgressType();
 
-   FInfo = new TQueueItem::TInfo();
 
-   Update();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TQueueItemProxy::~TQueueItemProxy()
 
- {
 
-   delete FProgressData;
 
-   delete FInfo;
 
- }
 
- //---------------------------------------------------------------------------
 
- TFileOperationProgressType * __fastcall TQueueItemProxy::GetProgressData()
 
- {
 
-   return (FProgressData->Operation == foNone) ? NULL : FProgressData;
 
- }
 
- //---------------------------------------------------------------------------
 
- __int64 __fastcall TQueueItemProxy::GetTotalTransferred()
 
- {
 
-   // want to show total transferred also for "completed" items,
 
-   // for which GetProgressData() is NULL
 
-   return
 
-     (FProgressData->Operation == Info->Operation) || (Status == TQueueItem::qsDone) ?
 
-       FProgressData->TotalTransferred : -1;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Update()
 
- {
 
-   DebugAssert(FQueueItem != NULL);
 
-   TQueueItem::TStatus PrevStatus = Status;
 
-   bool Result = FQueue->ItemGetData(FQueueItem, this);
 
-   if ((FQueueStatus != NULL) && (PrevStatus != Status))
 
-   {
 
-     FQueueStatus->ResetStats();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::ExecuteNow()
 
- {
 
-   return FQueue->ItemExecuteNow(FQueueItem);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Move(bool Sooner)
 
- {
 
-   bool Result = false;
 
-   int I = Index;
 
-   if (Sooner)
 
-   {
 
-     if (I > 0)
 
-     {
 
-       Result = Move(FQueueStatus->Items[I - 1]);
 
-     }
 
-   }
 
-   else
 
-   {
 
-     if (I < FQueueStatus->Count - 1)
 
-     {
 
-       Result = FQueueStatus->Items[I + 1]->Move(this);
 
-     }
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Move(TQueueItemProxy * BeforeItem)
 
- {
 
-   return FQueue->ItemMove(FQueueItem, BeforeItem->FQueueItem);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Delete()
 
- {
 
-   return FQueue->ItemDelete(FQueueItem);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Pause()
 
- {
 
-   return FQueue->ItemPause(FQueueItem, true);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::Resume()
 
- {
 
-   return FQueue->ItemPause(FQueueItem, false);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::ProcessUserAction()
 
- {
 
-   DebugAssert(FQueueItem != NULL);
 
-   bool Result;
 
-   FProcessingUserAction = true;
 
-   try
 
-   {
 
-     Result = FQueue->ItemProcessUserAction(FQueueItem, NULL);
 
-   }
 
-   __finally
 
-   {
 
-     FProcessingUserAction = false;
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::GetCPSLimit(unsigned long & CPSLimit)
 
- {
 
-   return FQueue->ItemGetCPSLimit(FQueueItem, CPSLimit);
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TQueueItemProxy::SetCPSLimit(unsigned long CPSLimit)
 
- {
 
-   return FQueue->ItemSetCPSLimit(FQueueItem, CPSLimit);
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TQueueItemProxy::GetIndex()
 
- {
 
-   DebugAssert(FQueueStatus != NULL);
 
-   int Index = FQueueStatus->FList->IndexOf(this);
 
-   DebugAssert(Index >= 0);
 
-   return Index;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TTerminalQueueStatus
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalQueueStatus::TTerminalQueueStatus() :
 
-   FList(NULL)
 
- {
 
-   FList = new TList();
 
-   ResetStats();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalQueueStatus::~TTerminalQueueStatus()
 
- {
 
-   for (int Index = 0; Index < FList->Count; Index++)
 
-   {
 
-     delete GetItem(Index);
 
-   }
 
-   delete FList;
 
-   FList = NULL;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueueStatus::ResetStats()
 
- {
 
-   FActiveCount = -1;
 
-   FActivePrimaryCount = -1;
 
-   FActiveAndPendingPrimaryCount = -1;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueueStatus::SetDoneCount(int Value)
 
- {
 
-   FDoneCount = Value;
 
-   ResetStats();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueueStatus::NeedStats()
 
- {
 
-   if (FActiveCount < 0)
 
-   {
 
-     FActiveCount = 0;
 
-     FActivePrimaryCount = 0;
 
-     FActiveAndPendingPrimaryCount = 0;
 
-     for (int Index = DoneCount; Index < Count; Index++)
 
-     {
 
-       bool Primary = GetItem(Index)->Info->Primary;
 
-       if (GetItem(Index)->Status != TQueueItem::qsPending)
 
-       {
 
-         FActiveCount++;
 
-         if (Primary)
 
-         {
 
-           FActivePrimaryCount++;
 
-         }
 
-       }
 
-       if (Primary)
 
-       {
 
-         FActiveAndPendingPrimaryCount++;
 
-       }
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueueStatus::GetActiveCount()
 
- {
 
-   NeedStats();
 
-   return FActiveCount;
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueueStatus::GetDoneAndActiveCount()
 
- {
 
-   return DoneCount + ActiveCount;
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueueStatus::GetActivePrimaryCount()
 
- {
 
-   NeedStats();
 
-   return FActivePrimaryCount;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalQueueStatus::IsOnlyOneActiveAndNoPending()
 
- {
 
-   return (ActivePrimaryCount == 1) && (ActiveAndPendingPrimaryCount == 1);
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueueStatus::GetActiveAndPendingPrimaryCount()
 
- {
 
-   NeedStats();
 
-   return FActiveAndPendingPrimaryCount;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueueStatus::Add(TQueueItemProxy * ItemProxy)
 
- {
 
-   ItemProxy->FQueueStatus = this;
 
-   int Index = FList->Count;
 
-   if (!ItemProxy->Info->Primary)
 
-   {
 
-     for (int I = 0; I < FList->Count; I++)
 
-     {
 
-       if (Items[I]->Info->GroupToken == ItemProxy->Info->GroupToken)
 
-       {
 
-         Index = I + 1;
 
-       }
 
-     }
 
-     DebugAssert(Index >= 0);
 
-   }
 
-   FList->Insert(Index, ItemProxy);
 
-   ResetStats();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalQueueStatus::Delete(TQueueItemProxy * ItemProxy)
 
- {
 
-   FList->Extract(ItemProxy);
 
-   ItemProxy->FQueueStatus = NULL;
 
-   ResetStats();
 
- }
 
- //---------------------------------------------------------------------------
 
- int __fastcall TTerminalQueueStatus::GetCount()
 
- {
 
-   return FList->Count;
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItemProxy * __fastcall TTerminalQueueStatus::GetItem(int Index)
 
- {
 
-   return reinterpret_cast<TQueueItemProxy *>(FList->Items[Index]);
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItemProxy * __fastcall TTerminalQueueStatus::FindByQueueItem(
 
-   TQueueItem * QueueItem)
 
- {
 
-   TQueueItemProxy * Item;
 
-   for (int Index = 0; Index < FList->Count; Index++)
 
-   {
 
-     Item = GetItem(Index);
 
-     if (Item->FQueueItem == QueueItem)
 
-     {
 
-       return Item;
 
-     }
 
-   }
 
-   return NULL;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TLocatedQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TLocatedQueueItem::TLocatedQueueItem(TTerminal * Terminal) :
 
-   TQueueItem()
 
- {
 
-   DebugAssert(Terminal != NULL);
 
-   FCurrentDir = Terminal->CurrentDirectory;
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TLocatedQueueItem::TLocatedQueueItem(const TLocatedQueueItem & Source) :
 
-   TQueueItem()
 
- {
 
-   FCurrentDir = Source.FCurrentDir;
 
- }
 
- //---------------------------------------------------------------------------
 
- UnicodeString __fastcall TLocatedQueueItem::StartupDirectory() const
 
- {
 
-   return FCurrentDir;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TLocatedQueueItem::DoExecute(TTerminal * Terminal)
 
- {
 
-   DebugAssert(Terminal != NULL);
 
-   Terminal->CurrentDirectory = FCurrentDir;
 
- }
 
- //---------------------------------------------------------------------------
 
- // TTransferQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TTransferQueueItem::TTransferQueueItem(TTerminal * Terminal,
 
-   TStrings * FilesToCopy, const UnicodeString & TargetDir,
 
-   const TCopyParamType * CopyParam, int Params, TOperationSide Side,
 
-   bool SingleFile, bool Parallel) :
 
-   TLocatedQueueItem(Terminal), FFilesToCopy(NULL), FCopyParam(NULL)
 
- {
 
-   FInfo->Operation = (Params & cpDelete ? foMove : foCopy);
 
-   FInfo->Side = Side;
 
-   FInfo->SingleFile = SingleFile;
 
-   DebugAssert(FilesToCopy != NULL);
 
-   FFilesToCopy = new TStringList();
 
-   for (int Index = 0; Index < FilesToCopy->Count; Index++)
 
-   {
 
-     FFilesToCopy->AddObject(FilesToCopy->Strings[Index],
 
-       ((FilesToCopy->Objects[Index] == NULL) || (Side == osLocal)) ? NULL :
 
-         dynamic_cast<TRemoteFile*>(FilesToCopy->Objects[Index])->Duplicate());
 
-   }
 
-   FTargetDir = TargetDir;
 
-   DebugAssert(CopyParam != NULL);
 
-   FCopyParam = new TCopyParamType(*CopyParam);
 
-   FParams = Params;
 
-   FParallel = Parallel;
 
-   FLastParallelOperationAdded = GetTickCount();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TTransferQueueItem::~TTransferQueueItem()
 
- {
 
-   for (int Index = 0; Index < FFilesToCopy->Count; Index++)
 
-   {
 
-     delete FFilesToCopy->Objects[Index];
 
-   }
 
-   delete FFilesToCopy;
 
-   delete FCopyParam;
 
- }
 
- //---------------------------------------------------------------------------
 
- unsigned long __fastcall TTransferQueueItem::DefaultCPSLimit()
 
- {
 
-   return FCopyParam->CPSLimit;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTransferQueueItem::DoExecute(TTerminal * Terminal)
 
- {
 
-   TLocatedQueueItem::DoExecute(Terminal);
 
-   DebugAssert(Terminal != NULL);
 
-   TParallelOperation ParallelOperation(FInfo->Side);
 
-   FParallelOperation = &ParallelOperation;
 
-   try
 
-   {
 
-     DoTransferExecute(Terminal, FParallelOperation);
 
-   }
 
-   __finally
 
-   {
 
-     FParallelOperation = NULL;
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTransferQueueItem::ProgressUpdated()
 
- {
 
-   TLocatedQueueItem::ProgressUpdated();
 
-   if (FParallel)
 
-   {
 
-     bool Add = false;
 
-     bool Force = false;
 
-     DWORD LastParallelOperationAddedPrev = 0;
 
-     {
 
-       TGuard Guard(FSection);
 
-       DebugAssert(FParallelOperation != NULL);
 
-       // Won't be initialized, if the operation is not eligible for parallel transfers (like cpDelete).
 
-       // We can probably move the check outside of the guard.
 
-       if (FParallelOperation->IsInitialized())
 
-       {
 
-         DebugAssert((FProgressData->Operation == foCopy) || (FProgressData->Operation == foCalculateSize));
 
-         if (FProgressData->Operation == foCopy)
 
-         {
 
-           Add = FParallelOperation->ShouldAddClient();
 
-           if (Add)
 
-           {
 
-             DWORD Now = GetTickCount();
 
-             Force =
 
-               (Now - FLastParallelOperationAdded >= 5*1000) &&
 
-               (TimeToSeconds(FProgressData->TotalTimeLeft()) >= FQueue->ParallelDurationThreshold);
 
-             LastParallelOperationAddedPrev = FLastParallelOperationAdded;
 
-             // update now already to prevent race condition, but we will have to rollback it back,
 
-             // if we actually do not add the parallel operation
 
-             FLastParallelOperationAdded = Now;
 
-           }
 
-         }
 
-       }
 
-     }
 
-     if (Add)
 
-     {
 
-       if (!FQueue->TryAddParallelOperation(this, Force))
 
-       {
 
-         TGuard Guard(FSection);
 
-         FLastParallelOperationAdded = LastParallelOperationAddedPrev;
 
-       }
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- TQueueItem * __fastcall TTransferQueueItem::CreateParallelOperation()
 
- {
 
-   DebugAssert(FParallelOperation != NULL);
 
-   FParallelOperation->AddClient();
 
-   return new TParallelTransferQueueItem(this, FParallelOperation);
 
- }
 
- //---------------------------------------------------------------------------
 
- // TUploadQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TUploadQueueItem::TUploadQueueItem(TTerminal * Terminal,
 
-   TStrings * FilesToCopy, const UnicodeString & TargetDir,
 
-   const TCopyParamType * CopyParam, int Params, bool SingleFile, bool Parallel) :
 
-   TTransferQueueItem(Terminal, FilesToCopy, TargetDir, CopyParam, Params, osLocal, SingleFile, Parallel)
 
- {
 
-   if (FilesToCopy->Count > 1)
 
-   {
 
-     if (FLAGSET(Params, cpTemporary))
 
-     {
 
-       FInfo->Source = L"";
 
-       FInfo->ModifiedLocal = L"";
 
-     }
 
-     else
 
-     {
 
-       ExtractCommonPath(FilesToCopy, FInfo->Source);
 
-       // this way the trailing backslash is preserved for root directories like D:\\
 
-       FInfo->Source = ExtractFileDir(IncludeTrailingBackslash(FInfo->Source));
 
-       FInfo->ModifiedLocal = FLAGCLEAR(Params, cpDelete) ? UnicodeString() :
 
-         IncludeTrailingBackslash(FInfo->Source);
 
-     }
 
-   }
 
-   else
 
-   {
 
-     if (FLAGSET(Params, cpTemporary))
 
-     {
 
-       FInfo->Source = ExtractFileName(FilesToCopy->Strings[0]);
 
-       FInfo->ModifiedLocal = L"";
 
-     }
 
-     else
 
-     {
 
-       DebugAssert(FilesToCopy->Count > 0);
 
-       FInfo->Source = FilesToCopy->Strings[0];
 
-       FInfo->ModifiedLocal = FLAGCLEAR(Params, cpDelete) ? UnicodeString() :
 
-         IncludeTrailingBackslash(ExtractFilePath(FInfo->Source));
 
-     }
 
-   }
 
-   FInfo->Destination =
 
-     UnixIncludeTrailingBackslash(TargetDir) + CopyParam->FileMask;
 
-   FInfo->ModifiedRemote = UnixIncludeTrailingBackslash(TargetDir);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TUploadQueueItem::DoTransferExecute(TTerminal * Terminal, TParallelOperation * ParallelOperation)
 
- {
 
-   Terminal->CopyToRemote(FFilesToCopy, FTargetDir, FCopyParam, FParams, ParallelOperation);
 
- }
 
- //---------------------------------------------------------------------------
 
- // TParallelTransferQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TParallelTransferQueueItem::TParallelTransferQueueItem(
 
-     const TLocatedQueueItem * ParentItem, TParallelOperation * ParallelOperation) :
 
-   TLocatedQueueItem(*ParentItem),
 
-   FParallelOperation(ParallelOperation)
 
- {
 
-   // deliberately not copying the ModifiedLocal and ModifiedRemote, not to trigger panel refresh, when sub-item completes
 
-   FInfo->Operation = ParentItem->FInfo->Operation;
 
-   FInfo->Side = ParentItem->FInfo->Side;
 
-   FInfo->Source = ParentItem->FInfo->Source;
 
-   FInfo->Destination = ParentItem->FInfo->Destination;
 
-   FInfo->SingleFile = DebugAlwaysFalse(ParentItem->FInfo->SingleFile);
 
-   FInfo->Primary = false;
 
-   FInfo->GroupToken = ParentItem->FInfo->GroupToken;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TParallelTransferQueueItem::DoExecute(TTerminal * Terminal)
 
- {
 
-   TLocatedQueueItem::DoExecute(Terminal);
 
-   Terminal->LogParallelTransfer(FParallelOperation);
 
-   TFileOperationProgressType OperationProgress(Terminal->OnProgress, Terminal->OnFinished, FParallelOperation->MainOperationProgress);
 
-   TFileOperation Operation = (FLAGSET(FParallelOperation->Params, cpDelete) ? foMove : foCopy);
 
-   bool Temp = FLAGSET(FParallelOperation->Params, cpTemporary);
 
-   OperationProgress.Start(
 
-     // CPS limit inherited from parent OperationProgress.
 
-     // Count not known and won't be needed as we will always have TotalSize as  we always transfer a single file at a time.
 
-     Operation, FParallelOperation->Side, -1, Temp, FParallelOperation->TargetDir, 0);
 
-   try
 
-   {
 
-     bool Continue = true;
 
-     do
 
-     {
 
-       int GotNext = Terminal->CopyToParallel(FParallelOperation, &OperationProgress);
 
-       if (GotNext < 0)
 
-       {
 
-         Continue = false;
 
-       }
 
-       else if (!FQueue->ContinueParallelOperation())
 
-       {
 
-         Continue = false;
 
-       }
 
-     }
 
-     while (Continue);
 
-   }
 
-   __finally
 
-   {
 
-     OperationProgress.Stop();
 
-     FParallelOperation->RemoveClient();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- // TDownloadQueueItem
 
- //---------------------------------------------------------------------------
 
- __fastcall TDownloadQueueItem::TDownloadQueueItem(TTerminal * Terminal,
 
-   TStrings * FilesToCopy, const UnicodeString & TargetDir,
 
-   const TCopyParamType * CopyParam, int Params, bool SingleFile, bool Parallel) :
 
-   TTransferQueueItem(Terminal, FilesToCopy, TargetDir, CopyParam, Params, osRemote, SingleFile, Parallel)
 
- {
 
-   if (FilesToCopy->Count > 1)
 
-   {
 
-     if (!UnixExtractCommonPath(FilesToCopy, FInfo->Source))
 
-     {
 
-       FInfo->Source = Terminal->CurrentDirectory;
 
-     }
 
-     FInfo->Source = UnixExcludeTrailingBackslash(FInfo->Source);
 
-     FInfo->ModifiedRemote = FLAGCLEAR(Params, cpDelete) ? UnicodeString() :
 
-       UnixIncludeTrailingBackslash(FInfo->Source);
 
-   }
 
-   else
 
-   {
 
-     DebugAssert(FilesToCopy->Count > 0);
 
-     FInfo->Source = FilesToCopy->Strings[0];
 
-     if (UnixExtractFilePath(FInfo->Source).IsEmpty())
 
-     {
 
-       FInfo->Source = UnixIncludeTrailingBackslash(Terminal->CurrentDirectory) +
 
-         FInfo->Source;
 
-       FInfo->ModifiedRemote = FLAGCLEAR(Params, cpDelete) ? UnicodeString() :
 
-         UnixIncludeTrailingBackslash(Terminal->CurrentDirectory);
 
-     }
 
-     else
 
-     {
 
-       FInfo->ModifiedRemote = FLAGCLEAR(Params, cpDelete) ? UnicodeString() :
 
-         UnixExtractFilePath(FInfo->Source);
 
-     }
 
-   }
 
-   if (FLAGSET(Params, cpTemporary))
 
-   {
 
-     FInfo->Destination = L"";
 
-   }
 
-   else
 
-   {
 
-     FInfo->Destination =
 
-       IncludeTrailingBackslash(TargetDir) + CopyParam->FileMask;
 
-   }
 
-   FInfo->ModifiedLocal = IncludeTrailingBackslash(TargetDir);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TDownloadQueueItem::DoTransferExecute(TTerminal * Terminal, TParallelOperation * ParallelOperation)
 
- {
 
-   Terminal->CopyToLocal(FFilesToCopy, FTargetDir, FCopyParam, FParams, ParallelOperation);
 
- }
 
- //---------------------------------------------------------------------------
 
- // TTerminalThread
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalThread::TTerminalThread(TTerminal * Terminal) :
 
-   TSignalThread(false), FTerminal(Terminal)
 
- {
 
-   FAction = NULL;
 
-   FActionEvent = CreateEvent(NULL, false, false, NULL);
 
-   FException = NULL;
 
-   FIdleException = NULL;
 
-   FOnIdle = NULL;
 
-   FUserAction = NULL;
 
-   FCancel = false;
 
-   FAbandoned = false;
 
-   FAllowAbandon = false;
 
-   FMainThread = GetCurrentThreadId();
 
-   FSection = new TCriticalSection();
 
-   FOnInformation = FTerminal->OnInformation;
 
-   FOnQueryUser = FTerminal->OnQueryUser;
 
-   FOnPromptUser = FTerminal->OnPromptUser;
 
-   FOnShowExtendedException = FTerminal->OnShowExtendedException;
 
-   FOnDisplayBanner = FTerminal->OnDisplayBanner;
 
-   FOnChangeDirectory = FTerminal->OnChangeDirectory;
 
-   FOnReadDirectory = FTerminal->OnReadDirectory;
 
-   FOnStartReadDirectory = FTerminal->OnStartReadDirectory;
 
-   FOnReadDirectoryProgress = FTerminal->OnReadDirectoryProgress;
 
-   FOnInitializeLog = FTerminal->OnInitializeLog;
 
-   FTerminal->OnInformation = TerminalInformation;
 
-   FTerminal->OnQueryUser = TerminalQueryUser;
 
-   FTerminal->OnPromptUser = TerminalPromptUser;
 
-   FTerminal->OnShowExtendedException = TerminalShowExtendedException;
 
-   FTerminal->OnDisplayBanner = TerminalDisplayBanner;
 
-   FTerminal->OnChangeDirectory = TerminalChangeDirectory;
 
-   FTerminal->OnReadDirectory = TerminalReadDirectory;
 
-   FTerminal->OnStartReadDirectory = TerminalStartReadDirectory;
 
-   FTerminal->OnReadDirectoryProgress = TerminalReadDirectoryProgress;
 
-   FTerminal->OnInitializeLog = TerminalInitializeLog;
 
-   Start();
 
- }
 
- //---------------------------------------------------------------------------
 
- __fastcall TTerminalThread::~TTerminalThread()
 
- {
 
-   Close();
 
-   CloseHandle(FActionEvent);
 
-   DebugAssert(FTerminal->OnInformation == TerminalInformation);
 
-   DebugAssert(FTerminal->OnQueryUser == TerminalQueryUser);
 
-   DebugAssert(FTerminal->OnPromptUser == TerminalPromptUser);
 
-   DebugAssert(FTerminal->OnShowExtendedException == TerminalShowExtendedException);
 
-   DebugAssert(FTerminal->OnDisplayBanner == TerminalDisplayBanner);
 
-   DebugAssert(FTerminal->OnChangeDirectory == TerminalChangeDirectory);
 
-   DebugAssert(FTerminal->OnReadDirectory == TerminalReadDirectory);
 
-   DebugAssert(FTerminal->OnStartReadDirectory == TerminalStartReadDirectory);
 
-   DebugAssert(FTerminal->OnReadDirectoryProgress == TerminalReadDirectoryProgress);
 
-   DebugAssert(FTerminal->OnInitializeLog == TerminalInitializeLog);
 
-   FTerminal->OnInformation = FOnInformation;
 
-   FTerminal->OnQueryUser = FOnQueryUser;
 
-   FTerminal->OnPromptUser = FOnPromptUser;
 
-   FTerminal->OnShowExtendedException = FOnShowExtendedException;
 
-   FTerminal->OnDisplayBanner = FOnDisplayBanner;
 
-   FTerminal->OnChangeDirectory = FOnChangeDirectory;
 
-   FTerminal->OnReadDirectory = FOnReadDirectory;
 
-   FTerminal->OnStartReadDirectory = FOnStartReadDirectory;
 
-   FTerminal->OnReadDirectoryProgress = FOnReadDirectoryProgress;
 
-   FTerminal->OnInitializeLog = FOnInitializeLog;
 
-   delete FSection;
 
-   if (FAbandoned)
 
-   {
 
-     delete FTerminal;
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::Cancel()
 
- {
 
-   FCancel = true;
 
-   FCancelAfter = IncMilliSecond(Now(), 1000);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::Idle()
 
- {
 
-   TGuard Guard(FSection);
 
-   // only when running user action already,
 
-   // so that the exception is caught, saved and actually
 
-   // passed back into the terminal thread, saved again
 
-   // and passed back to us
 
-   if ((FUserAction != NULL) && (FIdleException != NULL))
 
-   {
 
-     Rethrow(FIdleException);
 
-   }
 
-   FPendingIdle = true;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalOpen()
 
- {
 
-   RunAction(TerminalOpenEvent);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalReopen()
 
- {
 
-   RunAction(TerminalReopenEvent);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::RunAction(TNotifyEvent Action)
 
- {
 
-   DebugAssert(FAction == NULL);
 
-   DebugAssert(FException == NULL);
 
-   DebugAssert(FIdleException == NULL);
 
-   DebugAssert(FOnIdle != NULL);
 
-   FCancelled = false;
 
-   FAction = Action;
 
-   try
 
-   {
 
-     try
 
-     {
 
-       TriggerEvent();
 
-       bool Done = false;
 
-       const unsigned int MaxWait = 50;
 
-       unsigned int Wait = MaxWait;
 
-       do
 
-       {
 
-         switch (WaitForSingleObject(FActionEvent, Wait))
 
-         {
 
-           case WAIT_OBJECT_0:
 
-             Done = true;
 
-             break;
 
-           case WAIT_TIMEOUT:
 
-             if (FUserAction != NULL)
 
-             {
 
-               try
 
-               {
 
-                 FUserAction->Execute(NULL);
 
-               }
 
-               catch (Exception & E)
 
-               {
 
-                 SaveException(E, FException);
 
-               }
 
-               FUserAction = NULL;
 
-               TriggerEvent();
 
-               Wait = 0;
 
-             }
 
-             else
 
-             {
 
-               if (FOnIdle != NULL)
 
-               {
 
-                 FOnIdle(NULL);
 
-               }
 
-               Wait = std::min(Wait + 10, MaxWait);
 
-             }
 
-             break;
 
-           default:
 
-             throw Exception(L"Error waiting for background session task to complete");
 
-         }
 
-         if (AllowAbandon && !Done && FCancel && (Now() >= FCancelAfter))
 
-         {
 
-           TGuard Guard(FSection);
 
-           if (WaitForSingleObject(FActionEvent, 0) != WAIT_OBJECT_0)
 
-           {
 
-             FAbandoned = true;
 
-             FCancelled = true;
 
-             FatalAbort();
 
-           }
 
-         }
 
-       }
 
-       while (!Done);
 
-       if (Done)
 
-       {
 
-         Rethrow(FException);
 
-       }
 
-     }
 
-     __finally
 
-     {
 
-       FAction = NULL;
 
-       SAFE_DESTROY(FException);
 
-     }
 
-   }
 
-   catch(...)
 
-   {
 
-     if (FCancelled)
 
-     {
 
-       // even if the abort thrown as result of Cancel() was wrapped into
 
-       // some higher-level exception, normalize back to message-less fatal
 
-       // exception here
 
-       FatalAbort();
 
-     }
 
-     else
 
-     {
 
-       throw;
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalOpenEvent(TObject * /*Sender*/)
 
- {
 
-   FTerminal->Open();
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalReopenEvent(TObject * /*Sender*/)
 
- {
 
-   FTerminal->Reopen(0);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::ProcessEvent()
 
- {
 
-   DebugAssert(FEvent != NULL);
 
-   DebugAssert(FException == NULL);
 
-   try
 
-   {
 
-     FAction(NULL);
 
-   }
 
-   catch(Exception & E)
 
-   {
 
-     SaveException(E, FException);
 
-   }
 
-   {
 
-     TGuard Guard(FSection);
 
-     if (!FAbandoned)
 
-     {
 
-       SetEvent(FActionEvent);
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::Rethrow(Exception *& Exception)
 
- {
 
-   if (Exception != NULL)
 
-   {
 
-     try
 
-     {
 
-       RethrowException(Exception);
 
-     }
 
-     __finally
 
-     {
 
-       SAFE_DESTROY(Exception);
 
-     }
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::SaveException(Exception & E, Exception *& Exception)
 
- {
 
-   DebugAssert(Exception == NULL);
 
-   Exception = CloneException(&E);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::FatalAbort()
 
- {
 
-   if (FAbandoned)
 
-   {
 
-     // We cannot use TTerminal::FatalError as the terminal still runs on a backgroud thread,
 
-     // may have its TCallbackGuard armed right now.
 
-     throw ESshFatal(NULL, L"");
 
-   }
 
-   else
 
-   {
 
-     FTerminal->FatalAbort();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::CheckCancel()
 
- {
 
-   if (FCancel && !FCancelled)
 
-   {
 
-     FCancelled = true;
 
-     FatalAbort();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::WaitForUserAction(TUserAction * UserAction)
 
- {
 
-   DWORD Thread = GetCurrentThreadId();
 
-   // we can get called from the main thread from within Idle,
 
-   // should be only to call HandleExtendedException
 
-   if (Thread == FMainThread)
 
-   {
 
-     if (UserAction != NULL)
 
-     {
 
-       UserAction->Execute(NULL);
 
-     }
 
-   }
 
-   else
 
-   {
 
-     // we should be called from our thread only,
 
-     // with exception noted above
 
-     DebugAssert(Thread == FThreadId);
 
-     bool DoCheckCancel =
 
-       DebugAlwaysFalse(UserAction == NULL) || !UserAction->Force() || FAbandoned;
 
-     if (DoCheckCancel)
 
-     {
 
-       CheckCancel();
 
-     }
 
-     // have to save it as we can go recursive via TQueryParams::TimerEvent,
 
-     // see TTerminalThread::TerminalQueryUser
 
-     TUserAction * PrevUserAction = FUserAction;
 
-     try
 
-     {
 
-       FUserAction = UserAction;
 
-       while (true)
 
-       {
 
-         {
 
-           TGuard Guard(FSection);
 
-           // If idle exception is already set, we are only waiting
 
-           // for the main thread to pick it up
 
-           // (or at least to finish handling the user action, so
 
-           // that we rethrow the idle exception below)
 
-           // Also if idle exception is set, it is probable that terminal
 
-           // is not active anyway.
 
-           if (FTerminal->Active && FPendingIdle && (FIdleException == NULL))
 
-           {
 
-             FPendingIdle = false;
 
-             try
 
-             {
 
-               FTerminal->Idle();
 
-             }
 
-             catch (Exception & E)
 
-             {
 
-               SaveException(E, FIdleException);
 
-             }
 
-           }
 
-         }
 
-         int WaitResult = WaitForEvent(1000);
 
-         if (WaitResult == 0)
 
-         {
 
-           SAFE_DESTROY(FIdleException);
 
-           FatalAbort();
 
-         }
 
-         else if (WaitResult > 0)
 
-         {
 
-           break;
 
-         }
 
-       }
 
-       Rethrow(FException);
 
-       if (FIdleException != NULL)
 
-       {
 
-         // idle exception was not used to cancel the user action
 
-         // (if it where it would be already cloned into the FException above
 
-         // and rethrown)
 
-         Rethrow(FIdleException);
 
-       }
 
-     }
 
-     __finally
 
-     {
 
-       FUserAction = PrevUserAction;
 
-       SAFE_DESTROY(FException);
 
-     }
 
-     // Contrary to a call before, this is unconditional,
 
-     // otherwise cancelling authentication won't work,
 
-     // if it is tried only after the last user action
 
-     // (what is common, when cancelling while waiting for
 
-     // resolving of unresolvable host name, where the last user action is
 
-     // "resolving hostname" information action)
 
-     CheckCancel();
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalInformation(
 
-   TTerminal * Terminal, const UnicodeString & Str, bool Status, int Phase)
 
- {
 
-   TInformationUserAction Action(FOnInformation);
 
-   Action.Terminal = Terminal;
 
-   Action.Str = Str;
 
-   Action.Status = Status;
 
-   Action.Phase = Phase;
 
-   WaitForUserAction(&Action);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalQueryUser(TObject * Sender,
 
-   const UnicodeString Query, TStrings * MoreMessages, unsigned int Answers,
 
-   const TQueryParams * Params, unsigned int & Answer, TQueryType Type, void * Arg)
 
- {
 
-   DebugUsedParam(Arg);
 
-   DebugAssert(Arg == NULL);
 
-   // note about TQueryParams::TimerEvent
 
-   // So far there is only one use for this, the TSecureShell::SendBuffer,
 
-   // which should be thread-safe, as long as the terminal thread,
 
-   // is stopped waiting for OnQueryUser to finish.
 
-   // note about TQueryButtonAlias::OnClick
 
-   // So far there is only one use for this, the TClipboardHandler,
 
-   // which is thread-safe.
 
-   TQueryUserAction Action(FOnQueryUser);
 
-   Action.Sender = Sender;
 
-   Action.Query = Query;
 
-   Action.MoreMessages = MoreMessages;
 
-   Action.Answers = Answers;
 
-   Action.Params = Params;
 
-   Action.Answer = Answer;
 
-   Action.Type = Type;
 
-   WaitForUserAction(&Action);
 
-   Answer = Action.Answer;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalInitializeLog(TObject * Sender)
 
- {
 
-   if (FOnInitializeLog != NULL)
 
-   {
 
-     // never used, so not tested either
 
-     DebugFail();
 
-     TNotifyAction Action(FOnInitializeLog);
 
-     Action.Sender = Sender;
 
-     WaitForUserAction(&Action);
 
-   }
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalPromptUser(TTerminal * Terminal,
 
-   TPromptKind Kind, UnicodeString Name, UnicodeString Instructions, TStrings * Prompts,
 
-   TStrings * Results, bool & Result, void * Arg)
 
- {
 
-   DebugUsedParam(Arg);
 
-   DebugAssert(Arg == NULL);
 
-   TPromptUserAction Action(FOnPromptUser);
 
-   Action.Terminal = Terminal;
 
-   Action.Kind = Kind;
 
-   Action.Name = Name;
 
-   Action.Instructions = Instructions;
 
-   Action.Prompts = Prompts;
 
-   Action.Results->AddStrings(Results);
 
-   WaitForUserAction(&Action);
 
-   Results->Clear();
 
-   Results->AddStrings(Action.Results);
 
-   Result = Action.Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalShowExtendedException(
 
-   TTerminal * Terminal, Exception * E, void * Arg)
 
- {
 
-   DebugUsedParam(Arg);
 
-   DebugAssert(Arg == NULL);
 
-   TShowExtendedExceptionAction Action(FOnShowExtendedException);
 
-   Action.Terminal = Terminal;
 
-   Action.E = E;
 
-   WaitForUserAction(&Action);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalDisplayBanner(TTerminal * Terminal,
 
-   UnicodeString SessionName, const UnicodeString & Banner,
 
-   bool & NeverShowAgain, int Options, unsigned int & Params)
 
- {
 
-   TDisplayBannerAction Action(FOnDisplayBanner);
 
-   Action.Terminal = Terminal;
 
-   Action.SessionName = SessionName;
 
-   Action.Banner = Banner;
 
-   Action.NeverShowAgain = NeverShowAgain;
 
-   Action.Options = Options;
 
-   Action.Params = Params;
 
-   WaitForUserAction(&Action);
 
-   NeverShowAgain = Action.NeverShowAgain;
 
-   Params = Action.Params;
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalChangeDirectory(TObject * Sender)
 
- {
 
-   TNotifyAction Action(FOnChangeDirectory);
 
-   Action.Sender = Sender;
 
-   WaitForUserAction(&Action);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalReadDirectory(TObject * Sender, Boolean ReloadOnly)
 
- {
 
-   TReadDirectoryAction Action(FOnReadDirectory);
 
-   Action.Sender = Sender;
 
-   Action.ReloadOnly = ReloadOnly;
 
-   WaitForUserAction(&Action);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalStartReadDirectory(TObject * Sender)
 
- {
 
-   TNotifyAction Action(FOnStartReadDirectory);
 
-   Action.Sender = Sender;
 
-   WaitForUserAction(&Action);
 
- }
 
- //---------------------------------------------------------------------------
 
- void __fastcall TTerminalThread::TerminalReadDirectoryProgress(
 
-   TObject * Sender, int Progress, int ResolvedLinks, bool & Cancel)
 
- {
 
-   TReadDirectoryProgressAction Action(FOnReadDirectoryProgress);
 
-   Action.Sender = Sender;
 
-   Action.Progress = Progress;
 
-   Action.ResolvedLinks = ResolvedLinks;
 
-   Action.Cancel = Cancel;
 
-   WaitForUserAction(&Action);
 
-   Cancel = Action.Cancel;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalThread::Release()
 
- {
 
-   bool Result = !FAbandoned;
 
-   if (Result)
 
-   {
 
-     delete this;
 
-   }
 
-   else
 
-   {
 
-     // only now has the owner released ownership of the thread, so we are safe to kill outselves.
 
-     Terminate();
 
-   }
 
-   return Result;
 
- }
 
- //---------------------------------------------------------------------------
 
- bool __fastcall TTerminalThread::Finished()
 
- {
 
-   return TSimpleThread::Finished() || FAbandoned;
 
- }
 
 
  |