123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593 |
- //
- // FLEXNetworkObserver.m
- // Derived from:
- //
- // PDAFNetworkDomainController.m
- // PonyDebugger
- //
- // Created by Mike Lewis on 2/27/12.
- //
- // Licensed to Square, Inc. under one or more contributor license agreements.
- // See the LICENSE file distributed with this work for the terms under
- // which Square, Inc. licenses this file to you.
- //
- #import "FLEXNetworkObserver.h"
- #import "FLEXNetworkRecorder.h"
- #import "FLEXUtility.h"
- #import "NSObject+FLEX_Reflection.h"
- #import "FLEXMethod.h"
- #import <objc/runtime.h>
- #import <objc/message.h>
- #import <dispatch/queue.h>
- #include <dlfcn.h>
- NSString *const kFLEXNetworkObserverEnabledStateChangedNotification = @"kFLEXNetworkObserverEnabledStateChangedNotification";
- static NSString *const kFLEXNetworkObserverEnabledDefaultsKey = @"com.flex.FLEXNetworkObserver.enableOnLaunch";
- typedef void (^NSURLSessionAsyncCompletion)(id fileURLOrData, NSURLResponse *response, NSError *error);
- typedef NSURLSessionTask * (^NSURLSessionNewTaskMethod)(NSURLSession *, id, NSURLSessionAsyncCompletion);
- @interface FLEXInternalRequestState : NSObject
- @property (nonatomic, copy) NSURLRequest *request;
- @property (nonatomic) NSMutableData *dataAccumulator;
- @end
- @implementation FLEXInternalRequestState
- @end
- @interface FLEXNetworkObserver (NSURLConnectionHelpers)
- - (void)connection:(NSURLConnection *)connection willSendRequest:(NSURLRequest *)request redirectResponse:(NSURLResponse *)response delegate:(id<NSURLConnectionDelegate>)delegate;
- - (void)connection:(NSURLConnection *)connection didReceiveResponse:(NSURLResponse *)response delegate:(id<NSURLConnectionDelegate>)delegate;
- - (void)connection:(NSURLConnection *)connection didReceiveData:(NSData *)data delegate:(id<NSURLConnectionDelegate>)delegate;
- - (void)connectionDidFinishLoading:(NSURLConnection *)connection delegate:(id<NSURLConnectionDelegate>)delegate;
- - (void)connection:(NSURLConnection *)connection didFailWithError:(NSError *)error delegate:(id<NSURLConnectionDelegate>)delegate;
- - (void)connectionWillCancel:(NSURLConnection *)connection;
- @end
- @interface FLEXNetworkObserver (NSURLSessionTaskHelpers)
- - (void)URLSession:(NSURLSession *)session task:(NSURLSessionTask *)task willPerformHTTPRedirection:(NSHTTPURLResponse *)response newRequest:(NSURLRequest *)request completionHandler:(void (^)(NSURLRequest *))completionHandler delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session dataTask:(NSURLSessionDataTask *)dataTask didReceiveResponse:(NSURLResponse *)response completionHandler:(void (^)(NSURLSessionResponseDisposition disposition))completionHandler delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session dataTask:(NSURLSessionDataTask *)dataTask didReceiveData:(NSData *)data delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session dataTask:(NSURLSessionDataTask *)dataTask
- didBecomeDownloadTask:(NSURLSessionDownloadTask *)downloadTask delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session task:(NSURLSessionTask *)task didCompleteWithError:(NSError *)error delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session downloadTask:(NSURLSessionDownloadTask *)downloadTask didWriteData:(int64_t)bytesWritten totalBytesWritten:(int64_t)totalBytesWritten totalBytesExpectedToWrite:(int64_t)totalBytesExpectedToWrite delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSession:(NSURLSession *)session task:(NSURLSessionDownloadTask *)downloadTask didFinishDownloadingToURL:(NSURL *)location data:(NSData *)data delegate:(id<NSURLSessionDelegate>)delegate;
- - (void)URLSessionTaskWillResume:(NSURLSessionTask *)task;
- @end
- @interface FLEXNetworkObserver ()
- @property (nonatomic) NSMutableDictionary<NSString *, FLEXInternalRequestState *> *requestStatesForRequestIDs;
- @property (nonatomic) dispatch_queue_t queue;
- @end
- @implementation FLEXNetworkObserver
- #pragma mark - Public Methods
- + (void)setEnabled:(BOOL)enabled {
- BOOL previouslyEnabled = [self isEnabled];
-
- [NSUserDefaults.standardUserDefaults setBool:enabled forKey:kFLEXNetworkObserverEnabledDefaultsKey];
-
- if (enabled) {
- // Inject if needed. This injection is protected with a dispatch_once, so we're ok calling it multiple times.
- // By doing the injection lazily, we keep the impact of the tool lower when this feature isn't enabled.
- [self injectIntoAllNSURLConnectionDelegateClasses];
- }
-
- if (previouslyEnabled != enabled) {
- [NSNotificationCenter.defaultCenter postNotificationName:kFLEXNetworkObserverEnabledStateChangedNotification object:self];
- }
- }
- + (BOOL)isEnabled {
- return [[NSUserDefaults.standardUserDefaults objectForKey:kFLEXNetworkObserverEnabledDefaultsKey] boolValue];
- }
- + (void)load {
- // We don't want to do the swizzling from +load because not all the classes may be loaded at this point.
- dispatch_async(dispatch_get_main_queue(), ^{
- if ([self isEnabled]) {
- [self injectIntoAllNSURLConnectionDelegateClasses];
- }
- });
- }
- #pragma mark - Statics
- + (instancetype)sharedObserver {
- static FLEXNetworkObserver *sharedObserver = nil;
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- sharedObserver = [self new];
- });
- return sharedObserver;
- }
- + (NSString *)nextRequestID {
- return NSUUID.UUID.UUIDString;
- }
- #pragma mark Delegate Injection Convenience Methods
- /// All swizzled delegate methods should make use of this guard.
- /// This will prevent duplicated sniffing when the original implementation calls up to a superclass implementation which we've also swizzled.
- /// The superclass implementation (and implementations in classes above that) will be executed without interference if called from the original implementation.
- + (void)sniffWithoutDuplicationForObject:(NSObject *)object selector:(SEL)selector sniffingBlock:(void (^)(void))sniffingBlock originalImplementationBlock:(void (^)(void))originalImplementationBlock {
- // If we don't have an object to detect nested calls on, just run the original implementation and bail.
- // This case can happen if someone besides the URL loading system calls the delegate methods directly.
- // See https://github.com/Flipboard/FLEX/issues/61 for an example.
- if (!object) {
- originalImplementationBlock();
- return;
- }
- const void *key = selector;
- // Don't run the sniffing block if we're inside a nested call
- if (!objc_getAssociatedObject(object, key)) {
- sniffingBlock();
- }
- // Mark that we're calling through to the original so we can detect nested calls
- objc_setAssociatedObject(object, key, @YES, OBJC_ASSOCIATION_RETAIN_NONATOMIC);
- originalImplementationBlock();
- objc_setAssociatedObject(object, key, nil, OBJC_ASSOCIATION_RETAIN_NONATOMIC);
- }
- #pragma mark - Delegate Injection
- + (void)injectIntoAllNSURLConnectionDelegateClasses {
- // Only allow swizzling once.
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- // Swizzle any classes that implement one of these selectors.
- const SEL selectors[] = {
- @selector(connectionDidFinishLoading:),
- @selector(connection:willSendRequest:redirectResponse:),
- @selector(connection:didReceiveResponse:),
- @selector(connection:didReceiveData:),
- @selector(connection:didFailWithError:),
- @selector(URLSession:task:willPerformHTTPRedirection:newRequest:completionHandler:),
- @selector(URLSession:dataTask:didReceiveData:),
- @selector(URLSession:dataTask:didReceiveResponse:completionHandler:),
- @selector(URLSession:task:didCompleteWithError:),
- @selector(URLSession:dataTask:didBecomeDownloadTask:),
- @selector(URLSession:downloadTask:didWriteData:totalBytesWritten:totalBytesExpectedToWrite:),
- @selector(URLSession:downloadTask:didFinishDownloadingToURL:)
- };
- const int numSelectors = sizeof(selectors) / sizeof(SEL);
- Class *classes = NULL;
- int numClasses = objc_getClassList(NULL, 0);
- if (numClasses > 0) {
- classes = (__unsafe_unretained Class *)malloc(sizeof(Class) * numClasses);
- numClasses = objc_getClassList(classes, numClasses);
- for (NSInteger classIndex = 0; classIndex < numClasses; ++classIndex) {
- Class class = classes[classIndex];
- if (class == [FLEXNetworkObserver class]) {
- continue;
- }
- // Use the C API rather than NSObject methods to avoid sending messages
- // to classes we're not interested in swizzling, which could result
- // in us calling +initialize on potentially uninitialized classes.
- // NOTE: calling class_getInstanceMethod() DOES send +initialize
- // to the class. That's why we iterate through the method list.
- unsigned int methodCount = 0;
- Method *methods = class_copyMethodList(class, &methodCount);
- BOOL matchingSelectorFound = NO;
- for (unsigned int methodIndex = 0; methodIndex < methodCount; methodIndex++) {
- for (int selectorIndex = 0; selectorIndex < numSelectors; ++selectorIndex) {
- if (method_getName(methods[methodIndex]) == selectors[selectorIndex]) {
- [self injectIntoDelegateClass:class];
- matchingSelectorFound = YES;
- break;
- }
- }
- if (matchingSelectorFound) {
- break;
- }
- }
-
- free(methods);
- }
-
- free(classes);
- }
- [self injectIntoNSURLConnectionCancel];
- [self injectIntoNSURLSessionTaskResume];
- [self injectIntoNSURLConnectionAsynchronousClassMethod];
- [self injectIntoNSURLConnectionSynchronousClassMethod];
- [self injectIntoNSURLSessionAsyncDataAndDownloadTaskMethods];
- [self injectIntoNSURLSessionAsyncUploadTaskMethods];
- });
- }
- + (void)injectIntoDelegateClass:(Class)cls {
- // Connections
- [self injectWillSendRequestIntoDelegateClass:cls];
- [self injectDidReceiveDataIntoDelegateClass:cls];
- [self injectDidReceiveResponseIntoDelegateClass:cls];
- [self injectDidFinishLoadingIntoDelegateClass:cls];
- [self injectDidFailWithErrorIntoDelegateClass:cls];
-
- // Sessions
- [self injectTaskWillPerformHTTPRedirectionIntoDelegateClass:cls];
- [self injectTaskDidReceiveDataIntoDelegateClass:cls];
- [self injectTaskDidReceiveResponseIntoDelegateClass:cls];
- [self injectTaskDidCompleteWithErrorIntoDelegateClass:cls];
- [self injectRespondsToSelectorIntoDelegateClass:cls];
- // Data tasks
- [self injectDataTaskDidBecomeDownloadTaskIntoDelegateClass:cls];
- // Download tasks
- [self injectDownloadTaskDidWriteDataIntoDelegateClass:cls];
- [self injectDownloadTaskDidFinishDownloadingIntoDelegateClass:cls];
- }
- + (void)injectIntoNSURLConnectionCancel {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- Class class = [NSURLConnection class];
- SEL selector = @selector(cancel);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- Method originalCancel = class_getInstanceMethod(class, selector);
- void (^swizzleBlock)(NSURLConnection *) = ^(NSURLConnection *slf) {
- [FLEXNetworkObserver.sharedObserver connectionWillCancel:slf];
- ((void(*)(id, SEL))objc_msgSend)(
- slf, swizzledSelector
- );
- };
- IMP implementation = imp_implementationWithBlock(swizzleBlock);
- class_addMethod(class, swizzledSelector, implementation, method_getTypeEncoding(originalCancel));
- Method newCancel = class_getInstanceMethod(class, swizzledSelector);
- method_exchangeImplementations(originalCancel, newCancel);
- });
- }
- + (void)injectIntoNSURLSessionTaskResume {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- // In iOS 7 resume lives in __NSCFLocalSessionTask
- // In iOS 8 resume lives in NSURLSessionTask
- // In iOS 9 resume lives in __NSCFURLSessionTask
- // In iOS 14 resume lives in NSURLSessionTask
- Class baseResumeClass = Nil;
- if (![NSProcessInfo.processInfo respondsToSelector:@selector(operatingSystemVersion)]) {
- // iOS ... 7
- baseResumeClass = NSClassFromString(@"__NSCFLocalSessionTask");
- } else {
- NSInteger majorVersion = NSProcessInfo.processInfo.operatingSystemVersion.majorVersion;
- if (majorVersion < 9 || majorVersion >= 14) {
- // iOS 8 or iOS 14+
- baseResumeClass = [NSURLSessionTask class];
- } else {
- // iOS 9 ... 13
- baseResumeClass = NSClassFromString(@"__NSCFURLSessionTask");
- }
- }
-
- // Hook the base implementation of -resume
- IMP originalResume = [baseResumeClass instanceMethodForSelector:@selector(resume)];
- [self swizzleResumeSelector:@selector(resume) forClass:baseResumeClass];
-
- // *Sigh*
- //
- // So, multiple versions of AFNetworking 2.5.X swizzle -resume in various and
- // short-sighted ways. If you look through the version history from 2.5.0 upwards,
- // you'll see a variety of techniques were tried, including taking a private
- // subclass of NSURLSessionTask and calling class_addMethod with `originalResume`
- // below, so that a duplicate implementation of -resume exists in that class.
- //
- // This technique in particular is troublesome, because the implementation in
- // `baseResumeClass` is never called at all, which means our swizzle is never invoked.
- //
- // The only solution is a brute-force one: we must loop over the class tree
- // below `baseResumeClass` and check for all classes that implement `af_resume`.
- // if the IMP corresponding to that method is equal to `originalResume` then we
- // swizzle that in addition to swizzling `resume` on `baseResumeClass` above.
- //
- // However, we only go to the trouble at all if NSSelectorFromString
- // can even find an `"af_resume"` selector in the first place.
- SEL sel_af_resume = NSSelectorFromString(@"af_resume");
- if (sel_af_resume) {
- NSMutableArray<Class> *classTree = FLEXGetAllSubclasses(baseResumeClass, NO).mutableCopy;
- for (NSInteger i = 0; i < classTree.count; i++) {
- [classTree addObjectsFromArray:FLEXGetAllSubclasses(classTree[i], NO)];
- }
-
- for (Class current in classTree) {
- IMP af_resume = [current instanceMethodForSelector:sel_af_resume];
- if (af_resume == originalResume) {
- [self swizzleResumeSelector:sel_af_resume forClass:current];
- }
- }
- }
- });
- }
- + (void)swizzleResumeSelector:(SEL)selector forClass:(Class)class {
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- Method originalResume = class_getInstanceMethod(class, selector);
- IMP implementation = imp_implementationWithBlock(^(NSURLSessionTask *slf) {
-
- // iOS's internal HTTP parser finalization code is mysteriously not thread safe,
- // invoking it asynchronously has a chance to cause a `double free` crash.
- // This line below will ask for HTTPBody synchronously, make the HTTPParser
- // parse the request, and cache them in advance. After that the HTTPParser
- // will be finalized. Make sure other threads inspecting the request
- // won't trigger a race to finalize the parser.
- [slf.currentRequest HTTPBody];
- [FLEXNetworkObserver.sharedObserver URLSessionTaskWillResume:slf];
- ((void(*)(id, SEL))objc_msgSend)(
- slf, swizzledSelector
- );
- });
-
- class_addMethod(class, swizzledSelector, implementation, method_getTypeEncoding(originalResume));
- Method newResume = class_getInstanceMethod(class, swizzledSelector);
- method_exchangeImplementations(originalResume, newResume);
- }
- + (void)injectIntoNSURLConnectionAsynchronousClassMethod {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- Class class = objc_getMetaClass(class_getName([NSURLConnection class]));
- SEL selector = @selector(sendAsynchronousRequest:queue:completionHandler:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- typedef void (^AsyncCompletion)(
- NSURLResponse *response, NSData *data, NSError *error
- );
- typedef void (^SendAsyncRequestBlock)(
- Class, NSURLRequest *, NSOperationQueue *, AsyncCompletion
- );
- SendAsyncRequestBlock swizzleBlock = ^(Class slf,
- NSURLRequest *request,
- NSOperationQueue *queue,
- AsyncCompletion completion) {
- if (FLEXNetworkObserver.isEnabled) {
- NSString *requestID = [self nextRequestID];
- [FLEXNetworkRecorder.defaultRecorder
- recordRequestWillBeSentWithRequestID:requestID
- request:request
- redirectResponse:nil
- ];
-
- NSString *mechanism = [self mechanismFromClassMethod:selector onClass:class];
- [FLEXNetworkRecorder.defaultRecorder recordMechanism:mechanism forRequestID:requestID];
-
- AsyncCompletion wrapper = ^(NSURLResponse *response, NSData *data, NSError *error) {
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:response
- ];
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:data.length
- ];
- if (error) {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFailedWithRequestID:requestID
- error:error
- ];
- } else {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFinishedWithRequestID:requestID
- responseBody:data
- ];
- }
- // Call through to the original completion handler
- if (completion) {
- completion(response, data, error);
- }
- };
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, request, queue, wrapper
- );
- } else {
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, request, queue, completion
- );
- }
- };
-
- [FLEXUtility replaceImplementationOfKnownSelector:selector
- onClass:class withBlock:swizzleBlock swizzledSelector:swizzledSelector
- ];
- });
- }
- + (void)injectIntoNSURLConnectionSynchronousClassMethod {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- Class class = objc_getMetaClass(class_getName([NSURLConnection class]));
- SEL selector = @selector(sendSynchronousRequest:returningResponse:error:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- typedef NSData * (^AsyncCompletion)(Class, NSURLRequest *, NSURLResponse **, NSError **);
- AsyncCompletion swizzleBlock = ^NSData *(Class slf,
- NSURLRequest *request,
- NSURLResponse **response,
- NSError **error) {
- NSData *data = nil;
- if (FLEXNetworkObserver.isEnabled) {
- NSString *requestID = [self nextRequestID];
- [FLEXNetworkRecorder.defaultRecorder
- recordRequestWillBeSentWithRequestID:requestID
- request:request
- redirectResponse:nil
- ];
-
- NSString *mechanism = [self mechanismFromClassMethod:selector onClass:class];
- [FLEXNetworkRecorder.defaultRecorder recordMechanism:mechanism forRequestID:requestID];
- NSError *temporaryError = nil;
- NSURLResponse *temporaryResponse = nil;
- data = ((id(*)(id, SEL, id, NSURLResponse **, NSError **))objc_msgSend)(
- slf, swizzledSelector, request, &temporaryResponse, &temporaryError
- );
-
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:temporaryResponse
- ];
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:data.length
- ];
-
- if (temporaryError) {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFailedWithRequestID:requestID
- error:temporaryError
- ];
- } else {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFinishedWithRequestID:requestID
- responseBody:data
- ];
- }
-
- if (error) {
- *error = temporaryError;
- }
- if (response) {
- *response = temporaryResponse;
- }
- } else {
- data = ((id(*)(id, SEL, id, NSURLResponse **, NSError **))objc_msgSend)(
- slf, swizzledSelector, request, response, error
- );
- }
- return data;
- };
-
- [FLEXUtility replaceImplementationOfKnownSelector:selector
- onClass:class withBlock:swizzleBlock swizzledSelector:swizzledSelector
- ];
- });
- }
- + (void)injectIntoNSURLSessionAsyncDataAndDownloadTaskMethods {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- Class class = [NSURLSession class];
- // The method signatures here are close enough that
- // we can use the same logic to inject into all of them.
- const SEL selectors[] = {
- @selector(dataTaskWithRequest:completionHandler:),
- @selector(dataTaskWithURL:completionHandler:),
- @selector(downloadTaskWithRequest:completionHandler:),
- @selector(downloadTaskWithResumeData:completionHandler:),
- @selector(downloadTaskWithURL:completionHandler:)
- };
- const int numSelectors = sizeof(selectors) / sizeof(SEL);
- for (int selectorIndex = 0; selectorIndex < numSelectors; selectorIndex++) {
- SEL selector = selectors[selectorIndex];
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- if ([FLEXUtility instanceRespondsButDoesNotImplementSelector:selector class:class]) {
- // iOS 7 does not implement these methods on NSURLSession. We actually want to
- // swizzle __NSCFURLSession, which we can get from the class of the shared session
- class = [NSURLSession.sharedSession class];
- }
-
- typedef NSURLSessionTask * (^NSURLSessionNewTaskMethod)(
- NSURLSession *, id, NSURLSessionAsyncCompletion
- );
- NSURLSessionNewTaskMethod swizzleBlock = ^NSURLSessionTask *(NSURLSession *slf,
- id argument,
- NSURLSessionAsyncCompletion completion) {
- NSURLSessionTask *task = nil;
- // Check if network observing is on and a callback was provided
- if (FLEXNetworkObserver.isEnabled && completion) {
- NSString *requestID = [self nextRequestID];
- NSString *mechanism = [self mechanismFromClassMethod:selector onClass:class];
- // "Hook" the completion block
- NSURLSessionAsyncCompletion completionWrapper = [self
- asyncCompletionWrapperForRequestID:requestID
- mechanism:mechanism
- completion:completion
- ];
-
- // Call the original method
- task = ((id(*)(id, SEL, id, id))objc_msgSend)(
- slf, swizzledSelector, argument, completionWrapper
- );
- [self setRequestID:requestID forConnectionOrTask:task];
- } else {
- // Network observer disabled or no callback provided,
- // just pass through to the original method
- task = ((id(*)(id, SEL, id, id))objc_msgSend)(
- slf, swizzledSelector, argument, completion
- );
- }
- return task;
- };
-
- // Actually swizzle
- [FLEXUtility replaceImplementationOfKnownSelector:selector
- onClass:class withBlock:swizzleBlock swizzledSelector:swizzledSelector
- ];
- }
- });
- }
- + (void)injectIntoNSURLSessionAsyncUploadTaskMethods {
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- Class class = [NSURLSession class];
- // The method signatures here are close enough that we can use the same logic to inject into both of them.
- // Note that they have 3 arguments, so we can't easily combine with the data and download method above.
- typedef NSURLSessionUploadTask *(^UploadTaskMethod)(
- NSURLSession *, NSURLRequest *, id, NSURLSessionAsyncCompletion
- );
- const SEL selectors[] = {
- @selector(uploadTaskWithRequest:fromData:completionHandler:),
- @selector(uploadTaskWithRequest:fromFile:completionHandler:)
- };
- const int numSelectors = sizeof(selectors) / sizeof(SEL);
- for (int selectorIndex = 0; selectorIndex < numSelectors; selectorIndex++) {
- SEL selector = selectors[selectorIndex];
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- if ([FLEXUtility instanceRespondsButDoesNotImplementSelector:selector class:class]) {
- // iOS 7 does not implement these methods on NSURLSession. We actually want to
- // swizzle __NSCFURLSession, which we can get from the class of the shared session
- class = [NSURLSession.sharedSession class];
- }
-
- UploadTaskMethod swizzleBlock = ^NSURLSessionUploadTask *(NSURLSession * slf,
- NSURLRequest *request,
- id argument,
- NSURLSessionAsyncCompletion completion) {
- NSURLSessionUploadTask *task = nil;
- if (FLEXNetworkObserver.isEnabled && completion) {
- NSString *requestID = [self nextRequestID];
- NSString *mechanism = [self mechanismFromClassMethod:selector onClass:class];
- NSURLSessionAsyncCompletion completionWrapper = [self
- asyncCompletionWrapperForRequestID:requestID
- mechanism:mechanism
- completion:completion
- ];
-
- task = ((id(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, request, argument, completionWrapper
- );
- [self setRequestID:requestID forConnectionOrTask:task];
- } else {
- task = ((id(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, request, argument, completion
- );
- }
- return task;
- };
-
- [FLEXUtility replaceImplementationOfKnownSelector:selector
- onClass:class withBlock:swizzleBlock swizzledSelector:swizzledSelector
- ];
- }
- });
- }
- + (NSString *)mechanismFromClassMethod:(SEL)selector onClass:(Class)class {
- return [NSString stringWithFormat:@"+[%@ %@]", NSStringFromClass(class), NSStringFromSelector(selector)];
- }
- + (NSURLSessionAsyncCompletion)asyncCompletionWrapperForRequestID:(NSString *)requestID
- mechanism:(NSString *)mechanism
- completion:(NSURLSessionAsyncCompletion)completion {
- NSURLSessionAsyncCompletion completionWrapper = ^(id fileURLOrData, NSURLResponse *response, NSError *error) {
- [FLEXNetworkRecorder.defaultRecorder recordMechanism:mechanism forRequestID:requestID];
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:response
- ];
-
- NSData *data = nil;
- if ([fileURLOrData isKindOfClass:[NSURL class]]) {
- data = [NSData dataWithContentsOfURL:fileURLOrData];
- } else if ([fileURLOrData isKindOfClass:[NSData class]]) {
- data = fileURLOrData;
- }
-
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:data.length
- ];
-
- if (error) {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFailedWithRequestID:requestID
- error:error
- ];
- } else {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFinishedWithRequestID:requestID
- responseBody:data
- ];
- }
- // Call through to the original completion handler
- if (completion) {
- completion(fileURLOrData, response, error);
- }
- };
- return completionWrapper;
- }
- + (void)injectWillSendRequestIntoDelegateClass:(Class)cls {
- SEL selector = @selector(connection:willSendRequest:redirectResponse:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- Protocol *protocol = @protocol(NSURLConnectionDataDelegate);
- protocol = protocol ?: @protocol(NSURLConnectionDelegate);
- struct objc_method_description methodDescription = protocol_getMethodDescription(
- protocol, selector, NO, YES
- );
-
- typedef NSURLRequest *(^WillSendRequestBlock)(
- id<NSURLConnectionDelegate> slf, NSURLConnection *connection,
- NSURLRequest *request, NSURLResponse *response
- );
-
- WillSendRequestBlock undefinedBlock = ^NSURLRequest *(id slf,
- NSURLConnection *connection,
- NSURLRequest *request,
- NSURLResponse *response) {
- [FLEXNetworkObserver.sharedObserver
- connection:connection
- willSendRequest:request
- redirectResponse:response
- delegate:slf
- ];
- return request;
- };
-
- WillSendRequestBlock implementationBlock = ^NSURLRequest *(id slf,
- NSURLConnection *connection,
- NSURLRequest *request,
- NSURLResponse *response) {
- __block NSURLRequest *returnValue = nil;
- [self sniffWithoutDuplicationForObject:connection selector:selector sniffingBlock:^{
- undefinedBlock(slf, connection, request, response);
- } originalImplementationBlock:^{
- returnValue = ((id(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, connection, request, response
- );
- }];
- return returnValue;
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:methodDescription
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDidReceiveResponseIntoDelegateClass:(Class)cls {
- SEL selector = @selector(connection:didReceiveResponse:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- Protocol *protocol = @protocol(NSURLConnectionDataDelegate);
- protocol = protocol ?: @protocol(NSURLConnectionDelegate);
- struct objc_method_description description = protocol_getMethodDescription(
- protocol, selector, NO, YES
- );
-
- typedef void (^DidReceiveResponseBlock)(
- id<NSURLConnectionDelegate> slf, NSURLConnection *connection, NSURLResponse *response
- );
-
- DidReceiveResponseBlock undefinedBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSURLResponse *response) {
- [FLEXNetworkObserver.sharedObserver connection:connection
- didReceiveResponse:response delegate:slf
- ];
- };
-
- DidReceiveResponseBlock implementationBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSURLResponse *response) {
- [self sniffWithoutDuplicationForObject:connection selector:selector sniffingBlock:^{
- undefinedBlock(slf, connection, response);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id))objc_msgSend)(
- slf, swizzledSelector, connection, response
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDidReceiveDataIntoDelegateClass:(Class)cls {
- SEL selector = @selector(connection:didReceiveData:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- Protocol *protocol = @protocol(NSURLConnectionDataDelegate);
- protocol = protocol ?: @protocol(NSURLConnectionDelegate);
- struct objc_method_description description = protocol_getMethodDescription(
- protocol, selector, NO, YES
- );
-
- typedef void (^DidReceiveDataBlock)(
- id<NSURLConnectionDelegate> slf, NSURLConnection *connection, NSData *data
- );
-
- DidReceiveDataBlock undefinedBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSData *data) {
- [FLEXNetworkObserver.sharedObserver connection:connection
- didReceiveData:data delegate:slf
- ];
- };
-
- DidReceiveDataBlock implementationBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSData *data) {
- [self sniffWithoutDuplicationForObject:connection selector:selector sniffingBlock:^{
- undefinedBlock(slf, connection, data);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id))objc_msgSend)(
- slf, swizzledSelector, connection, data
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDidFinishLoadingIntoDelegateClass:(Class)cls {
- SEL selector = @selector(connectionDidFinishLoading:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- Protocol *protocol = @protocol(NSURLConnectionDataDelegate);
- protocol = protocol ?: @protocol(NSURLConnectionDelegate);
- struct objc_method_description description = protocol_getMethodDescription(
- protocol, selector, NO, YES
- );
-
- typedef void (^FinishLoadingBlock)(id<NSURLConnectionDelegate> slf, NSURLConnection *connection);
-
- FinishLoadingBlock undefinedBlock = ^(id<NSURLConnectionDelegate> slf, NSURLConnection *connection) {
- [FLEXNetworkObserver.sharedObserver connectionDidFinishLoading:connection delegate:slf];
- };
-
- FinishLoadingBlock implementationBlock = ^(id<NSURLConnectionDelegate> slf, NSURLConnection *connection) {
- [self sniffWithoutDuplicationForObject:connection selector:selector sniffingBlock:^{
- undefinedBlock(slf, connection);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id))objc_msgSend)(
- slf, swizzledSelector, connection
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDidFailWithErrorIntoDelegateClass:(Class)cls {
- SEL selector = @selector(connection:didFailWithError:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLConnectionDelegate), selector, NO, YES
- );
-
- typedef void (^DidFailWithErrorBlock)(
- id<NSURLConnectionDelegate> slf, NSURLConnection *connection, NSError *error
- );
-
- DidFailWithErrorBlock undefinedBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSError *error) {
- [FLEXNetworkObserver.sharedObserver connection:connection
- didFailWithError:error delegate:slf
- ];
- };
-
- DidFailWithErrorBlock implementationBlock = ^(id<NSURLConnectionDelegate> slf,
- NSURLConnection *connection,
- NSError *error) {
- [self sniffWithoutDuplicationForObject:connection selector:selector sniffingBlock:^{
- undefinedBlock(slf, connection, error);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id))objc_msgSend)(
- slf, swizzledSelector, connection, error
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectTaskWillPerformHTTPRedirectionIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:task:willPerformHTTPRedirection:newRequest:completionHandler:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionTaskDelegate), selector, NO, YES
- );
-
- typedef void (^HTTPRedirectionBlock)(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSHTTPURLResponse *response,
- NSURLRequest *newRequest,
- void(^completionHandler)(NSURLRequest *));
-
- HTTPRedirectionBlock undefinedBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSHTTPURLResponse *response,
- NSURLRequest *newRequest,
- void(^completionHandler)(NSURLRequest *)) {
- [FLEXNetworkObserver.sharedObserver
- URLSession:session task:task
- willPerformHTTPRedirection:response
- newRequest:newRequest
- completionHandler:completionHandler
- delegate:slf
- ];
- completionHandler(newRequest);
- };
- HTTPRedirectionBlock implementationBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSHTTPURLResponse *response,
- NSURLRequest *newRequest,
- void(^completionHandler)(NSURLRequest *)) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- [FLEXNetworkObserver.sharedObserver
- URLSession:session task:task
- willPerformHTTPRedirection:response
- newRequest:newRequest
- completionHandler:completionHandler
- delegate:slf
- ];
- } originalImplementationBlock:^{
- ((id(*)(id, SEL, id, id, id, id, void(^)(NSURLRequest *)))objc_msgSend)(
- slf, swizzledSelector, session, task, response, newRequest, completionHandler
- );
- }];
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectTaskDidReceiveDataIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:dataTask:didReceiveData:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDataDelegate), selector, NO, YES
- );
-
- typedef void (^DidReceiveDataBlock)(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSData *data);
- DidReceiveDataBlock undefinedBlock = ^(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSData *data) {
- [FLEXNetworkObserver.sharedObserver URLSession:session
- dataTask:dataTask didReceiveData:data delegate:slf
- ];
- };
-
- DidReceiveDataBlock implementationBlock = ^(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSData *data) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- undefinedBlock(slf, session, dataTask, data);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, session, dataTask, data
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDataTaskDidBecomeDownloadTaskIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:dataTask:didBecomeDownloadTask:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDataDelegate), selector, NO, YES
- );
- typedef void (^DidBecomeDownloadTaskBlock)(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLSessionDownloadTask *downloadTask);
- DidBecomeDownloadTaskBlock undefinedBlock = ^(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLSessionDownloadTask *downloadTask) {
- [FLEXNetworkObserver.sharedObserver URLSession:session
- dataTask:dataTask didBecomeDownloadTask:downloadTask delegate:slf
- ];
- };
- DidBecomeDownloadTaskBlock implementationBlock = ^(id<NSURLSessionDataDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLSessionDownloadTask *downloadTask) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- undefinedBlock(slf, session, dataTask, downloadTask);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, session, dataTask, downloadTask
- );
- }];
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectTaskDidReceiveResponseIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:dataTask:didReceiveResponse:completionHandler:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDataDelegate), selector, NO, YES
- );
-
- typedef void (^DidReceiveResponseBlock)(id<NSURLSessionDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLResponse *response,
- void(^completion)(NSURLSessionResponseDisposition));
-
- DidReceiveResponseBlock undefinedBlock = ^(id<NSURLSessionDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLResponse *response,
- void(^completion)(NSURLSessionResponseDisposition)) {
- [FLEXNetworkObserver.sharedObserver
- URLSession:session
- dataTask:dataTask
- didReceiveResponse:response
- completionHandler:completion
- delegate:slf
- ];
- completion(NSURLSessionResponseAllow);
- };
-
- DidReceiveResponseBlock implementationBlock = ^(id<NSURLSessionDelegate> slf,
- NSURLSession *session,
- NSURLSessionDataTask *dataTask,
- NSURLResponse *response,
- void(^completion)(NSURLSessionResponseDisposition )) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- [FLEXNetworkObserver.sharedObserver
- URLSession:session
- dataTask:dataTask
- didReceiveResponse:response
- completionHandler:completion
- delegate:slf
- ];
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, id, void(^)(NSURLSessionResponseDisposition)))objc_msgSend)(
- slf, swizzledSelector, session, dataTask, response, completion
- );
- }];
- };
-
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectTaskDidCompleteWithErrorIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:task:didCompleteWithError:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
-
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDataDelegate), selector, NO, YES
- );
-
- typedef void (^DidCompleteWithErrorBlock)(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSError *error);
- DidCompleteWithErrorBlock undefinedBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSError *error) {
- [FLEXNetworkObserver.sharedObserver URLSession:session
- task:task didCompleteWithError:error delegate:slf
- ];
- };
-
- DidCompleteWithErrorBlock implementationBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionTask *task,
- NSError *error) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- undefinedBlock(slf, session, task, error);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, session, task, error
- );
- }];
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- // Used for overriding AFNetworking behavior
- + (void)injectRespondsToSelectorIntoDelegateClass:(Class)cls {
- SEL selector = @selector(respondsToSelector:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- //Protocol *protocol = @protocol(NSURLSessionTaskDelegate);
- Method method = class_getInstanceMethod(cls, selector);
- struct objc_method_description methodDescription = *method_getDescription(method);
- typedef BOOL (^RespondsToSelectorImpl)(id self, SEL sel);
- RespondsToSelectorImpl undefinedBlock = ^(id slf, SEL sel) {
- return YES;
- };
- RespondsToSelectorImpl implementationBlock = ^(id<NSURLSessionTaskDelegate> slf, SEL sel) {
- if (sel == @selector(URLSession:dataTask:didReceiveResponse:completionHandler:)) {
- return undefinedBlock(slf, sel);
- }
- return ((BOOL(*)(id, SEL, SEL))objc_msgSend)(slf, swizzledSelector, sel);
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:methodDescription
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDownloadTaskDidFinishDownloadingIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:downloadTask:didFinishDownloadingToURL:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDownloadDelegate), selector, NO, YES
- );
- typedef void (^DidFinishDownloadingBlock)(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- NSURL *location);
- DidFinishDownloadingBlock undefinedBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- NSURL *location) {
- NSData *data = [NSData dataWithContentsOfFile:location.relativePath];
- [FLEXNetworkObserver.sharedObserver URLSession:session
- task:task didFinishDownloadingToURL:location data:data delegate:slf
- ];
- };
- DidFinishDownloadingBlock implementationBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- NSURL *location) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- undefinedBlock(slf, session, task, location);
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, id))objc_msgSend)(
- slf, swizzledSelector, session, task, location
- );
- }];
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- + (void)injectDownloadTaskDidWriteDataIntoDelegateClass:(Class)cls {
- SEL selector = @selector(URLSession:downloadTask:didWriteData:totalBytesWritten:totalBytesExpectedToWrite:);
- SEL swizzledSelector = [FLEXUtility swizzledSelectorForSelector:selector];
- struct objc_method_description description = protocol_getMethodDescription(
- @protocol(NSURLSessionDownloadDelegate), selector, NO, YES
- );
- typedef void (^DidWriteDataBlock)(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- int64_t bytesWritten,
- int64_t totalBytesWritten,
- int64_t totalBytesExpectedToWrite);
- DidWriteDataBlock undefinedBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- int64_t bytesWritten,
- int64_t totalBytesWritten,
- int64_t totalBytesExpectedToWrite) {
- [FLEXNetworkObserver.sharedObserver URLSession:session
- downloadTask:task didWriteData:bytesWritten
- totalBytesWritten:totalBytesWritten
- totalBytesExpectedToWrite:totalBytesExpectedToWrite
- delegate:slf
- ];
- };
- DidWriteDataBlock implementationBlock = ^(id<NSURLSessionTaskDelegate> slf,
- NSURLSession *session,
- NSURLSessionDownloadTask *task,
- int64_t bytesWritten,
- int64_t totalBytesWritten,
- int64_t totalBytesExpectedToWrite) {
- [self sniffWithoutDuplicationForObject:session selector:selector sniffingBlock:^{
- undefinedBlock(
- slf, session, task, bytesWritten,
- totalBytesWritten, totalBytesExpectedToWrite
- );
- } originalImplementationBlock:^{
- ((void(*)(id, SEL, id, id, int64_t, int64_t, int64_t))objc_msgSend)(
- slf, swizzledSelector, session, task, bytesWritten,
- totalBytesWritten, totalBytesExpectedToWrite
- );
- }];
- };
- [FLEXUtility replaceImplementationOfSelector:selector
- withSelector:swizzledSelector
- forClass:cls
- withMethodDescription:description
- implementationBlock:implementationBlock
- undefinedBlock:undefinedBlock
- ];
- }
- static char const * const kFLEXRequestIDKey = "kFLEXRequestIDKey";
- + (NSString *)requestIDForConnectionOrTask:(id)connectionOrTask {
- NSString *requestID = objc_getAssociatedObject(connectionOrTask, kFLEXRequestIDKey);
- if (!requestID) {
- requestID = [self nextRequestID];
- [self setRequestID:requestID forConnectionOrTask:connectionOrTask];
- }
- return requestID;
- }
- + (void)setRequestID:(NSString *)requestID forConnectionOrTask:(id)connectionOrTask {
- objc_setAssociatedObject(
- connectionOrTask, kFLEXRequestIDKey, requestID, OBJC_ASSOCIATION_RETAIN_NONATOMIC
- );
- }
- #pragma mark - Initialization
- - (id)init {
- self = [super init];
- if (self) {
- self.requestStatesForRequestIDs = [NSMutableDictionary new];
- self.queue = dispatch_queue_create(
- "com.flex.FLEXNetworkObserver", DISPATCH_QUEUE_SERIAL
- );
- }
-
- return self;
- }
- #pragma mark - Private Methods
- - (void)performBlock:(dispatch_block_t)block {
- if ([[self class] isEnabled]) {
- dispatch_async(_queue, block);
- }
- }
- - (FLEXInternalRequestState *)requestStateForRequestID:(NSString *)requestID {
- FLEXInternalRequestState *requestState = self.requestStatesForRequestIDs[requestID];
- if (!requestState) {
- requestState = [FLEXInternalRequestState new];
- [self.requestStatesForRequestIDs setObject:requestState forKey:requestID];
- }
-
- return requestState;
- }
- - (void)removeRequestStateForRequestID:(NSString *)requestID {
- [self.requestStatesForRequestIDs removeObjectForKey:requestID];
- }
- @end
- @implementation FLEXNetworkObserver (NSURLConnectionHelpers)
- - (void)connection:(NSURLConnection *)connection
- willSendRequest:(NSURLRequest *)request
- redirectResponse:(NSURLResponse *)response
- delegate:(id<NSURLConnectionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:connection];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- requestState.request = request;
-
- [FLEXNetworkRecorder.defaultRecorder
- recordRequestWillBeSentWithRequestID:requestID
- request:request
- redirectResponse:response
- ];
-
- NSString *mechanism = [NSString stringWithFormat:
- @"NSURLConnection (delegate: %@)", [delegate class]
- ];
- [FLEXNetworkRecorder.defaultRecorder recordMechanism:mechanism forRequestID:requestID];
- }];
- }
- - (void)connection:(NSURLConnection *)connection
- didReceiveResponse:(NSURLResponse *)response
- delegate:(id<NSURLConnectionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:connection];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- requestState.dataAccumulator = [NSMutableData new];
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:response
- ];
- }];
- }
- - (void)connection:(NSURLConnection *)connection
- didReceiveData:(NSData *)data
- delegate:(id<NSURLConnectionDelegate>)delegate {
- // Just to be safe since we're doing this async
- data = [data copy];
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:connection];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- [requestState.dataAccumulator appendData:data];
-
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:data.length
- ];
- }];
- }
- - (void)connectionDidFinishLoading:(NSURLConnection *)connection
- delegate:(id<NSURLConnectionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:connection];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFinishedWithRequestID:requestID
- responseBody:requestState.dataAccumulator
- ];
- [self removeRequestStateForRequestID:requestID];
- }];
- }
- - (void)connection:(NSURLConnection *)connection
- didFailWithError:(NSError *)error
- delegate:(id<NSURLConnectionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:connection];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- // Cancellations can occur prior to the willSendRequest:...
- // NSURLConnection delegate call. These are pretty common
- // and clutter up the logs. Only record the failure if the
- // recorder already knows about the request through willSendRequest:...
- if (requestState.request) {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFailedWithRequestID:requestID error:error
- ];
- }
-
- [self removeRequestStateForRequestID:requestID];
- }];
- }
- - (void)connectionWillCancel:(NSURLConnection *)connection {
- [self performBlock:^{
- // Mimic the behavior of NSURLSession which is to create an error on cancellation.
- NSDictionary<NSString *, id> *userInfo = @{ NSLocalizedDescriptionKey : @"cancelled" };
- NSError *error = [NSError errorWithDomain:NSURLErrorDomain
- code:NSURLErrorCancelled userInfo:userInfo
- ];
- [self connection:connection didFailWithError:error delegate:nil];
- }];
- }
- @end
- @implementation FLEXNetworkObserver (NSURLSessionTaskHelpers)
- - (void)URLSession:(NSURLSession *)session
- task:(NSURLSessionTask *)task
- willPerformHTTPRedirection:(NSHTTPURLResponse *)response
- newRequest:(NSURLRequest *)request
- completionHandler:(void (^)(NSURLRequest *))completionHandler
- delegate:(id<NSURLSessionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:task];
- [FLEXNetworkRecorder.defaultRecorder
- recordRequestWillBeSentWithRequestID:requestID
- request:request
- redirectResponse:response
- ];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- dataTask:(NSURLSessionDataTask *)dataTask
- didReceiveResponse:(NSURLResponse *)response
- completionHandler:(void (^)(NSURLSessionResponseDisposition))completionHandler
- delegate:(id<NSURLSessionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:dataTask];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- requestState.dataAccumulator = [NSMutableData new];
- NSString *requestMechanism = [NSString stringWithFormat:
- @"NSURLSessionDataTask (delegate: %@)", [delegate class]
- ];
- [FLEXNetworkRecorder.defaultRecorder
- recordMechanism:requestMechanism
- forRequestID:requestID
- ];
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:response
- ];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- dataTask:(NSURLSessionDataTask *)dataTask
- didBecomeDownloadTask:(NSURLSessionDownloadTask *)downloadTask
- delegate:(id<NSURLSessionDelegate>)delegate {
- [self performBlock:^{
- // By setting the request ID of the download task to match the data task,
- // it can pick up where the data task left off.
- NSString *requestID = [[self class] requestIDForConnectionOrTask:dataTask];
- [[self class] setRequestID:requestID forConnectionOrTask:downloadTask];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- dataTask:(NSURLSessionDataTask *)dataTask
- didReceiveData:(NSData *)data
- delegate:(id<NSURLSessionDelegate>)delegate {
- // Just to be safe since we're doing this async
- data = [data copy];
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:dataTask];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- [requestState.dataAccumulator appendData:data];
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:data.length
- ];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- task:(NSURLSessionTask *)task
- didCompleteWithError:(NSError *)error
- delegate:(id<NSURLSessionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:task];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- if (error) {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFailedWithRequestID:requestID error:error
- ];
- } else {
- [FLEXNetworkRecorder.defaultRecorder
- recordLoadingFinishedWithRequestID:requestID
- responseBody:requestState.dataAccumulator
- ];
- }
- [self removeRequestStateForRequestID:requestID];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- downloadTask:(NSURLSessionDownloadTask *)downloadTask
- didWriteData:(int64_t)bytesWritten
- totalBytesWritten:(int64_t)totalBytesWritten
- totalBytesExpectedToWrite:(int64_t)totalBytesExpectedToWrite
- delegate:(id<NSURLSessionDelegate>)delegate {
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:downloadTask];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- if (!requestState.dataAccumulator) {
- requestState.dataAccumulator = [NSMutableData new];
- [FLEXNetworkRecorder.defaultRecorder
- recordResponseReceivedWithRequestID:requestID
- response:downloadTask.response
- ];
- NSString *requestMechanism = [NSString stringWithFormat:
- @"NSURLSessionDownloadTask (delegate: %@)", [delegate class]
- ];
- [FLEXNetworkRecorder.defaultRecorder
- recordMechanism:requestMechanism
- forRequestID:requestID
- ];
- }
- [FLEXNetworkRecorder.defaultRecorder
- recordDataReceivedWithRequestID:requestID
- dataLength:bytesWritten
- ];
- }];
- }
- - (void)URLSession:(NSURLSession *)session
- task:(NSURLSessionDownloadTask *)downloadTask
- didFinishDownloadingToURL:(NSURL *)location data:(NSData *)data
- delegate:(id<NSURLSessionDelegate>)delegate {
- data = [data copy];
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:downloadTask];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- [requestState.dataAccumulator appendData:data];
- }];
- }
- - (void)URLSessionTaskWillResume:(NSURLSessionTask *)task {
- // Since resume can be called multiple times on the same task, only treat the first resume as
- // the equivalent to connection:willSendRequest:...
- [self performBlock:^{
- NSString *requestID = [[self class] requestIDForConnectionOrTask:task];
- FLEXInternalRequestState *requestState = [self requestStateForRequestID:requestID];
- if (!requestState.request) {
- requestState.request = task.currentRequest;
- [FLEXNetworkRecorder.defaultRecorder
- recordRequestWillBeSentWithRequestID:requestID
- request:task.currentRequest
- redirectResponse:nil
- ];
- }
- }];
- }
- @end
|