Search in sources :

Example 1 with PRUDPPacketHandlerException

use of com.biglybt.net.udp.uc.PRUDPPacketHandlerException in project BiglyBT by BiglySoftware.

the class TrackerStatus method runScrapesSupport.

protected void runScrapesSupport(ArrayList<TRTrackerScraperResponseImpl> allResponses, boolean force) {
    try {
        if (Logger.isEnabled()) {
            Logger.log(new LogEvent(LOGID, "TrackerStatus: scraping '" + scrapeURL + "', for " + allResponses.size() + " of " + hashes.size() + " hashes" + ", single_hash_scrapes: " + (bSingleHashScrapes ? "Y" : "N")));
        }
        boolean original_bSingleHashScrapes = bSingleHashScrapes;
        boolean disable_all_scrapes = !COConfigurationManager.getBooleanParameter("Tracker Client Scrape Enable");
        byte[] scrape_reply = null;
        List<HashWrapper> hashesInQuery = new ArrayList<>(allResponses.size());
        List<TRTrackerScraperResponseImpl> responsesInQuery = new ArrayList<>(allResponses.size());
        List<HashWrapper> hashesForUDP = new ArrayList<>();
        List<TRTrackerScraperResponseImpl> responsesForUDP = new ArrayList<>();
        List<TRTrackerScraperResponseImpl> activeResponses = responsesInQuery;
        try {
            // if URL already includes a query component then just append our
            // params
            HashWrapper one_of_the_hashes = null;
            // TRTrackerScraperResponseImpl one_of_the_responses = null;
            char first_separator = scrapeURL.indexOf('?') == -1 ? '?' : '&';
            String info_hash = "";
            String flags = "";
            for (TRTrackerScraperResponseImpl response : allResponses) {
                HashWrapper hash = response.getHash();
                if (Logger.isEnabled())
                    Logger.log(new LogEvent(TorrentUtils.getDownloadManager(hash), LOGID, "TrackerStatus: " + scrapeURL + ": scraping, single_hash_scrapes = " + bSingleHashScrapes));
                if (!scraper.isNetworkEnabled(hash, tracker_url)) {
                    response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                    response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "networkdisabled"));
                    scraper.scrapeReceived(response);
                } else if ((!force) && (disable_all_scrapes || !scraper.isTorrentScrapable(hash))) {
                    response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                    response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "disabled"));
                    scraper.scrapeReceived(response);
                } else {
                    hashesInQuery.add(hash);
                    responsesInQuery.add(response);
                    response.setStatus(TRTrackerScraperResponse.ST_SCRAPING, MessageText.getString(SS + "scraping"));
                    // technically haven't recieved a scrape yet, but we need
                    // to notify listeners (the ones that display status)
                    scraper.scrapeReceived(response);
                    // the client-id stuff RELIES on info_hash being the FIRST
                    // parameter added by
                    // us to the URL, so don't change it!
                    info_hash += ((one_of_the_hashes != null) ? '&' : first_separator) + "info_hash=";
                    info_hash += URLEncoder.encode(new String(hash.getBytes(), Constants.BYTE_ENCODING), Constants.BYTE_ENCODING).replaceAll("\\+", "%20");
                    Object[] extensions = scraper.getExtensions(hash);
                    if (extensions != null) {
                        if (extensions[0] != null) {
                            info_hash += (String) extensions[0];
                        }
                        flags += (Character) extensions[1];
                    } else {
                        flags += TRTrackerScraperClientResolver.FL_NONE;
                    }
                    one_of_the_hashes = hash;
                    if (hashesForUDP.size() < 70) {
                        hashesForUDP.add(hash);
                        responsesForUDP.add(response);
                    }
                }
            }
            if (one_of_the_hashes == null) {
                return;
            }
            String request = scrapeURL + info_hash;
            if (az_tracker) {
                String port_details = TRTrackerUtils.getPortsForURL();
                request += port_details;
                request += "&azsf=" + flags + "&azver=" + TRTrackerAnnouncer.AZ_TRACKER_VERSION_CURRENT;
            }
            URL reqUrl = new URL(request);
            if (Logger.isEnabled())
                Logger.log(new LogEvent(LOGID, "Accessing scrape interface using url : " + reqUrl));
            ByteArrayOutputStream message = new ByteArrayOutputStream();
            long scrapeStartTime = SystemTime.getCurrentTime();
            URL redirect_url = null;
            String protocol = reqUrl.getProtocol();
            URL udpScrapeURL = null;
            boolean auto_probe = false;
            if (protocol.equalsIgnoreCase("udp")) {
                if (udpScrapeEnabled) {
                    udpScrapeURL = reqUrl;
                } else {
                    throw (new IOException("UDP Tracker protocol disabled"));
                }
            } else if (protocol.equalsIgnoreCase("http") && !az_tracker && scrapeCount % autoUDPscrapeEvery == 0 && udpProbeEnabled && udpScrapeEnabled) {
                String tracker_network = AENetworkClassifier.categoriseAddress(reqUrl.getHost());
                if (tracker_network == AENetworkClassifier.AT_PUBLIC) {
                    udpScrapeURL = new URL(reqUrl.toString().replaceFirst("^http", "udp"));
                    auto_probe = true;
                }
            }
            if (udpScrapeURL == null) {
                if (!az_tracker && !tcpScrapeEnabled) {
                    String tracker_network = AENetworkClassifier.categoriseAddress(reqUrl.getHost());
                    if (tracker_network == AENetworkClassifier.AT_PUBLIC) {
                        throw (new IOException("HTTP Tracker protocol disabled"));
                    }
                }
            }
            try {
                // set context in case authentication dialog is required
                TorrentUtils.setTLSTorrentHash(one_of_the_hashes);
                if (udpScrapeURL != null) {
                    activeResponses = responsesForUDP;
                    boolean success = scrapeUDP(reqUrl, message, hashesForUDP, !auto_probe);
                    if ((!success || message.size() == 0) && !protocol.equalsIgnoreCase("udp")) {
                        // automatic UDP probe failed, use HTTP again
                        udpScrapeURL = null;
                        message.reset();
                        if (autoUDPscrapeEvery < 16)
                            autoUDPscrapeEvery <<= 1;
                        if (Logger.isEnabled())
                            Logger.log(new LogEvent(LOGID, LogEvent.LT_INFORMATION, "redirection of http scrape [" + scrapeURL + "] to udp failed, will retry in " + autoUDPscrapeEvery + " scrapes"));
                    } else if (success && !protocol.equalsIgnoreCase("udp")) {
                        if (Logger.isEnabled())
                            Logger.log(new LogEvent(LOGID, LogEvent.LT_INFORMATION, "redirection of http scrape [" + scrapeURL + "] to udp successful"));
                        autoUDPscrapeEvery = 1;
                        TRTrackerUtils.setUDPProbeResult(reqUrl, true);
                    }
                }
                scrapeCount++;
                if (udpScrapeURL == null) {
                    activeResponses = responsesInQuery;
                    redirect_url = scrapeHTTP(hashesInQuery, reqUrl, message);
                }
            } finally {
                TorrentUtils.setTLSTorrentHash(null);
            }
            scrape_reply = message.toByteArray();
            Map map = BDecoder.decode(scrape_reply);
            boolean this_is_az_tracker = map.get("aztracker") != null;
            if (az_tracker != this_is_az_tracker) {
                az_tracker = this_is_az_tracker;
                TRTrackerUtils.setAZTracker(tracker_url, az_tracker);
            }
            Map mapFiles = (Map) map.get("files");
            if (Logger.isEnabled())
                Logger.log(new LogEvent(LOGID, "Response from scrape interface " + scrapeURL + ": " + ((mapFiles == null) ? "null" : "" + mapFiles.size()) + " returned"));
            int iMinRequestInterval = 0;
            if (map != null) {
                /* "The spec":
					 * files
					 *   infohash
					 *   complete
					 *   incomplete
					 *   downloaded
					 *   name
					 *  flags
					 *    min_request_interval
					 *  failure reason
					 */
                /*
					 * files infohash complete incomplete downloaded name flags
					 * min_request_interval
					 */
                Map mapFlags = (Map) map.get("flags");
                if (mapFlags != null) {
                    Long longScrapeValue = (Long) mapFlags.get("min_request_interval");
                    if (longScrapeValue != null)
                        iMinRequestInterval = longScrapeValue.intValue();
                    // Tracker owners want this log entry
                    if (Logger.isEnabled())
                        Logger.log(new LogEvent(LOGID, "Received min_request_interval of " + iMinRequestInterval));
                }
            }
            if (mapFiles == null || mapFiles.size() == 0) {
                if (bSingleHashScrapes && map.containsKey("complete") && map.containsKey("incomplete")) {
                    int complete = MapUtils.getMapInt(map, "complete", 0);
                    int incomplete = MapUtils.getMapInt(map, "incomplete", 0);
                    TRTrackerScraperResponseImpl response = (TRTrackerScraperResponseImpl) activeResponses.get(0);
                    response.setPeers(incomplete);
                    response.setSeeds(complete);
                    int minRequestInterval = MapUtils.getMapInt(map, "interval", FAULTY_SCRAPE_RETRY_INTERVAL);
                    int scrapeInterval = TRTrackerScraperResponseImpl.calcScrapeIntervalSecs(minRequestInterval, complete);
                    long nextScrapeTime = SystemTime.getCurrentTime() + (scrapeInterval * 1000);
                    response.setNextScrapeStartTime(nextScrapeTime);
                    response.setStatus(TRTrackerScraperResponse.ST_ONLINE, "Tracker returned Announce from scrape call");
                    response.setScrapeStartTime(scrapeStartTime);
                    scraper.scrapeReceived(response);
                    return;
                }
                // custom extension here to handle "failure reason" returned for
                // scrapes
                byte[] failure_reason_bytes = map == null ? null : (byte[]) map.get("failure reason");
                if (failure_reason_bytes != null) {
                    long nextScrapeTime = SystemTime.getCurrentTime() + ((iMinRequestInterval == 0) ? FAULTY_SCRAPE_RETRY_INTERVAL : iMinRequestInterval * 1000);
                    for (TRTrackerScraperResponseImpl response : activeResponses) {
                        response.setNextScrapeStartTime(nextScrapeTime);
                        response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + new String(failure_reason_bytes, Constants.DEFAULT_ENCODING));
                        // notifiy listeners
                        scraper.scrapeReceived(response);
                    }
                } else {
                    if (activeResponses.size() > 1) {
                        // multi were requested, 0 returned. Therefore, multi not
                        // supported
                        bSingleHashScrapes = true;
                        if (Logger.isEnabled())
                            Logger.log(new LogEvent(LOGID, LogEvent.LT_WARNING, scrapeURL + " doesn't properly support " + "multi-hash scrapes"));
                        for (TRTrackerScraperResponseImpl response : activeResponses) {
                            response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "invalid"));
                            // notifiy listeners
                            scraper.scrapeReceived(response);
                        }
                    } else {
                        long nextScrapeTime = SystemTime.getCurrentTime() + ((iMinRequestInterval == 0) ? NOHASH_RETRY_INTERVAL : iMinRequestInterval * 1000);
                        // 1 was requested, 0 returned. Therefore, hash not found.
                        TRTrackerScraperResponseImpl response = (TRTrackerScraperResponseImpl) activeResponses.get(0);
                        response.setNextScrapeStartTime(nextScrapeTime);
                        response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "nohash"));
                        // notifiy listeners
                        scraper.scrapeReceived(response);
                    }
                }
                return;
            }
            /*
				 * If we requested mutliple hashes, but only one was returned, revert
				 * to Single Hash Scrapes, but continue on to process the one has that
				 * was returned (it may be a random one from the list)
				 */
            if (!bSingleHashScrapes && activeResponses.size() > 1 && mapFiles.size() == 1) {
                bSingleHashScrapes = true;
                if (Logger.isEnabled())
                    Logger.log(new LogEvent(LOGID, LogEvent.LT_WARNING, scrapeURL + " only returned " + mapFiles.size() + " hash scrape(s), but we asked for " + activeResponses.size()));
            }
            for (TRTrackerScraperResponseImpl response : activeResponses) {
                // LGLogger.log( "decoding response #" +i+ ": " +
                // ByteFormatter.nicePrint( response.getHash(), true ) );
                // retrieve the scrape data for the relevent infohash
                Map scrapeMap = (Map) mapFiles.get(new String(response.getHash().getBytes(), Constants.BYTE_ENCODING));
                if (scrapeMap == null) {
                    // some trackers that return only 1 hash return a random one!
                    if (activeResponses.size() == 1 || mapFiles.size() != 1) {
                        response.setNextScrapeStartTime(SystemTime.getCurrentTime() + NOHASH_RETRY_INTERVAL);
                        response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "nohash"));
                        // notifiy listeners
                        scraper.scrapeReceived(response);
                    } else if (scraper.isTorrentScrapable(response.getHash())) {
                        // This tracker doesn't support multiple hash requests.
                        // revert status to what it was
                        response.revertStatus();
                        if (response.getStatus() == TRTrackerScraperResponse.ST_SCRAPING) {
                            // System.out.println("Hash " +
                            // ByteFormatter.nicePrint(response.getHash(), true) + "
                            // mysteriously reverted to ST_SCRAPING!");
                            // response.setStatus(TRTrackerScraperResponse.ST_ONLINE, "");
                            response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                            response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "invalid"));
                        } else {
                            // force single-hash scrapes here
                            bSingleHashScrapes = true;
                            if (original_bSingleHashScrapes) {
                                response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                            }
                        }
                        // notifiy listeners
                        scraper.scrapeReceived(response);
                    // if this was the first scrape request in the list,
                    // TrackerChecker
                    // will attempt to scrape again because we didn't reset the
                    // nextscrapestarttime. But the next time, bSingleHashScrapes
                    // will be true, and only 1 has will be requested, so there
                    // will not be infinite looping
                    }
                // System.out.println("scrape: hash missing from reply");
                } else {
                    // retrieve values
                    Long l_seeds = (Long) scrapeMap.get("complete");
                    Long l_peers = (Long) scrapeMap.get("incomplete");
                    Long l_comp = (Long) scrapeMap.get("downloaded");
                    // expected but deal with missing as some trackers ommit :(
                    int seeds = l_seeds == null ? 0 : l_seeds.intValue();
                    // expected but deal with missing
                    int peers = l_peers == null ? 0 : l_peers.intValue();
                    // optional
                    int completed = l_comp == null ? -1 : l_comp.intValue();
                    // make sure we dont use invalid replies
                    if (seeds < 0 || peers < 0 || completed < -1) {
                        if (Logger.isEnabled()) {
                            HashWrapper hash = response.getHash();
                            Logger.log(new LogEvent(TorrentUtils.getDownloadManager(hash), LOGID, "Invalid scrape response from '" + reqUrl + "': map = " + scrapeMap));
                        }
                        // manager will run scrapes for each individual hash.
                        if (activeResponses.size() > 1 && bSingleHashScrapes) {
                            response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "invalid"));
                            scraper.scrapeReceived(response);
                            continue;
                        }
                        response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                        response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString(SSErr + "invalid") + " " + (seeds < 0 ? MessageText.getString("MyTorrentsView.seeds") + " == " + seeds + ". " : "") + (peers < 0 ? MessageText.getString("MyTorrentsView.peers") + " == " + peers + ". " : "") + (completed < 0 ? MessageText.getString("MyTorrentsView.completed") + " == " + completed + ". " : ""));
                        scraper.scrapeReceived(response);
                        continue;
                    }
                    int scrapeInterval = TRTrackerScraperResponseImpl.calcScrapeIntervalSecs(iMinRequestInterval, seeds);
                    long nextScrapeTime = SystemTime.getCurrentTime() + (scrapeInterval * 1000);
                    response.setNextScrapeStartTime(nextScrapeTime);
                    // create the response
                    response.setScrapeStartTime(scrapeStartTime);
                    response.setSeeds(seeds);
                    response.setPeers(peers);
                    response.setCompleted(completed);
                    response.setStatus(TRTrackerScraperResponse.ST_ONLINE, MessageText.getString(SS + "ok"));
                    // notifiy listeners
                    scraper.scrapeReceived(response);
                    try {
                        if (activeResponses.size() == 1 && redirect_url != null) {
                            // we only deal with redirects for single urls - if the tracker wants to
                            // redirect one of a group is has to force single-hash scrapes anyway
                            String redirect_str = redirect_url.toString();
                            int s_pos = redirect_str.indexOf("/scrape");
                            if (s_pos != -1) {
                                URL new_url = new URL(redirect_str.substring(0, s_pos) + "/announce" + redirect_str.substring(s_pos + 7));
                                if (scraper.redirectTrackerUrl(response.getHash(), tracker_url, new_url)) {
                                    removeHash(response.getHash());
                                }
                            }
                        }
                    } catch (Throwable e) {
                        Debug.printStackTrace(e);
                    }
                }
            }
        // for responses
        } catch (NoClassDefFoundError ignoreSSL) {
            // javax/net/ssl/SSLSocket
            for (TRTrackerScraperResponseImpl response : activeResponses) {
                response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + ignoreSSL.getMessage());
                // notifiy listeners
                scraper.scrapeReceived(response);
            }
        } catch (FileNotFoundException e) {
            for (TRTrackerScraperResponseImpl response : activeResponses) {
                response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + MessageText.getString("DownloadManager.error.filenotfound"));
                // notifiy listeners
                scraper.scrapeReceived(response);
            }
        } catch (SocketException e) {
            setAllError(activeResponses, e);
        } catch (SocketTimeoutException e) {
            setAllError(activeResponses, e);
        } catch (UnknownHostException e) {
            setAllError(activeResponses, e);
        } catch (PRUDPPacketHandlerException e) {
            setAllError(activeResponses, e);
        } catch (BEncodingException e) {
            setAllError(activeResponses, e);
        } catch (Exception e) {
            // for apache we can get error 414 - URL too long. simplest solution
            // for this
            // is to fall back to single scraping
            String error_message = e.getMessage();
            if (error_message != null) {
                if (error_message.contains(" 500 ") || error_message.contains(" 400 ") || error_message.contains(" 403 ") || error_message.contains(" 404 ") || error_message.contains(" 501 ")) {
                    // various errors that have a 99% chance of happening on
                    // any other scrape request
                    setAllError(activeResponses, e);
                    return;
                }
                if (error_message.contains("414") && !bSingleHashScrapes) {
                    bSingleHashScrapes = true;
                    // Skip the setuing up the response.  We want to scrape again
                    return;
                }
            }
            String msg = Debug.getNestedExceptionMessage(e);
            if (scrape_reply != null) {
                String trace_data;
                if (scrape_reply.length <= 150) {
                    trace_data = new String(scrape_reply);
                } else {
                    trace_data = new String(scrape_reply, 0, 150) + "...";
                }
                msg += " [" + trace_data + "]";
            }
            for (TRTrackerScraperResponseImpl response : activeResponses) {
                if (Logger.isEnabled()) {
                    HashWrapper hash = response.getHash();
                    Logger.log(new LogEvent(TorrentUtils.getDownloadManager(hash), LOGID, LogEvent.LT_ERROR, "Error from scrape interface " + scrapeURL + " : " + msg + " (" + e.getClass() + ")"));
                }
                response.setNextScrapeStartTime(SystemTime.getCurrentTime() + FAULTY_SCRAPE_RETRY_INTERVAL);
                response.setStatus(TRTrackerScraperResponse.ST_ERROR, MessageText.getString(SS + "error") + msg);
                // notifiy listeners
                scraper.scrapeReceived(response);
            }
        }
    } catch (Throwable t) {
        Debug.out("runScrapesSupport failed", t);
    } finally {
        numActiveScrapes.decrementAndGet();
    }
}
Also used : TRTrackerScraperResponseImpl(com.biglybt.core.tracker.client.impl.TRTrackerScraperResponseImpl) FileNotFoundException(java.io.FileNotFoundException) LogEvent(com.biglybt.core.logging.LogEvent) ByteArrayOutputStream(java.io.ByteArrayOutputStream) IOException(java.io.IOException) ClientIDException(com.biglybt.pif.clientid.ClientIDException) PRUDPPacketHandlerException(com.biglybt.net.udp.uc.PRUDPPacketHandlerException) IOException(java.io.IOException) FileNotFoundException(java.io.FileNotFoundException) PRUDPPacketHandlerException(com.biglybt.net.udp.uc.PRUDPPacketHandlerException)

Example 2 with PRUDPPacketHandlerException

use of com.biglybt.net.udp.uc.PRUDPPacketHandlerException in project BiglyBT by BiglySoftware.

the class TrackerStatus method scrapeUDP.

protected boolean scrapeUDP(URL reqUrl, ByteArrayOutputStream message, List hashes, boolean do_auth_test) throws Exception {
    Map rootMap = new HashMap();
    Map files = new ByteEncodedKeyHashMap();
    rootMap.put("files", files);
    /*
		 * reduce network traffic by only scraping UDP when the torrent isn't
		 * running as UDP version 2 contains scrape data in the announce
		 * response
		 */
    /* removed implementation for the time being

		for (Iterator it = hashes.iterator(); it.hasNext();)
		{
			HashWrapper hash = (HashWrapper) it.next();
			if (PRUDPPacketTracker.VERSION == 2 && scraper.isTorrentDownloading(hash))
			{
				if (Logger.isEnabled())
					Logger.log(new LogEvent(TorrentUtils.getDownloadManager(hash), LOGID, LogEvent.LT_WARNING, "Scrape of " + reqUrl + " skipped as torrent running and " + "therefore scrape data available in " + "announce replies"));
				// easiest approach here is to brew up a response that looks like the current one
				Map file = new HashMap();
				byte[] resp_hash = hash.getBytes();
				// System.out.println("got hash:" + ByteFormatter.nicePrint( resp_hash, true ));
				files.put(new String(resp_hash, Constants.BYTE_ENCODING), file);
				file.put("complete", new Long(current_response.getSeeds()));
				file.put("downloaded", new Long(-1)); // unknown
				file.put("incomplete", new Long(current_response.getPeers()));
				byte[] data = BEncoder.encode(rootMap);
				message.write(data);
				return true;
			}
		}

		*/
    reqUrl = TRTrackerUtils.adjustURLForHosting(reqUrl);
    PasswordAuthentication auth = null;
    boolean auth_ok = false;
    try {
        if (do_auth_test && UrlUtils.queryHasParameter(reqUrl.getQuery(), "auth", false)) {
            auth = SESecurityManager.getPasswordAuthentication("UDP Tracker", reqUrl);
        }
        int port = UDPNetworkManager.getSingleton().getUDPNonDataListeningPortNumber();
        PRUDPPacketHandler handler = PRUDPPacketHandlerFactory.getHandler(port);
        InetSocketAddress destination = new InetSocketAddress(reqUrl.getHost(), reqUrl.getPort() == -1 ? 80 : reqUrl.getPort());
        handler = handler.openSession(destination);
        try {
            String failure_reason = null;
            for (int retry_loop = 0; retry_loop < PRUDPPacketTracker.DEFAULT_RETRY_COUNT; retry_loop++) {
                try {
                    PRUDPPacket connect_request = new PRUDPPacketRequestConnect();
                    PRUDPPacket reply = handler.sendAndReceive(auth, connect_request, destination);
                    if (reply.getAction() == PRUDPPacketTracker.ACT_REPLY_CONNECT) {
                        PRUDPPacketReplyConnect connect_reply = (PRUDPPacketReplyConnect) reply;
                        long my_connection = connect_reply.getConnectionId();
                        PRUDPPacketRequestScrape scrape_request = new PRUDPPacketRequestScrape(my_connection, hashes);
                        reply = handler.sendAndReceive(auth, scrape_request, destination);
                        if (reply.getAction() == PRUDPPacketTracker.ACT_REPLY_SCRAPE) {
                            auth_ok = true;
                            if (PRUDPPacketTracker.VERSION == 1) {
                                PRUDPPacketReplyScrape scrape_reply = (PRUDPPacketReplyScrape) reply;
                                /*
								int	interval = scrape_reply.getInterval();

								if ( interval != 0 ){

									map.put( "interval", new Long(interval ));
								}
								*/
                                byte[][] reply_hashes = scrape_reply.getHashes();
                                int[] complete = scrape_reply.getComplete();
                                int[] downloaded = scrape_reply.getDownloaded();
                                int[] incomplete = scrape_reply.getIncomplete();
                                for (int i = 0; i < reply_hashes.length; i++) {
                                    Map file = new HashMap();
                                    byte[] resp_hash = reply_hashes[i];
                                    // System.out.println("got hash:" + ByteFormatter.nicePrint( resp_hash, true ));
                                    files.put(new String(resp_hash, Constants.BYTE_ENCODING), file);
                                    file.put("complete", new Long(complete[i]));
                                    file.put("downloaded", new Long(downloaded[i]));
                                    file.put("incomplete", new Long(incomplete[i]));
                                }
                                byte[] data = BEncoder.encode(rootMap);
                                message.write(data);
                                return true;
                            } else {
                                PRUDPPacketReplyScrape2 scrape_reply = (PRUDPPacketReplyScrape2) reply;
                                /*
								int	interval = scrape_reply.getInterval();

								if ( interval != 0 ){

									map.put( "interval", new Long(interval ));
								}
								*/
                                int[] complete = scrape_reply.getComplete();
                                int[] downloaded = scrape_reply.getDownloaded();
                                int[] incomplete = scrape_reply.getIncomplete();
                                int i = 0;
                                for (Iterator it = hashes.iterator(); it.hasNext() && i < complete.length; i++) {
                                    HashWrapper hash = (HashWrapper) it.next();
                                    Map file = new HashMap();
                                    file.put("complete", new Long(complete[i]));
                                    file.put("downloaded", new Long(downloaded[i]));
                                    file.put("incomplete", new Long(incomplete[i]));
                                    files.put(new String(hash.getBytes(), Constants.BYTE_ENCODING), file);
                                }
                                // System.out.println("got hash:" + ByteFormatter.nicePrint( resp_hash, true ));
                                byte[] data = BEncoder.encode(rootMap);
                                message.write(data);
                                return true;
                            }
                        } else {
                            failure_reason = ((PRUDPPacketReplyError) reply).getMessage();
                            if (Logger.isEnabled())
                                Logger.log(new LogEvent(LOGID, LogEvent.LT_ERROR, "Response from scrape interface " + reqUrl + " : " + failure_reason));
                            break;
                        }
                    } else {
                        failure_reason = ((PRUDPPacketReplyError) reply).getMessage();
                        if (Logger.isEnabled())
                            Logger.log(new LogEvent(LOGID, LogEvent.LT_ERROR, "Response from scrape interface " + reqUrl + " : " + ((PRUDPPacketReplyError) reply).getMessage()));
                        break;
                    }
                } catch (PRUDPPacketHandlerException e) {
                    if (e.getMessage() == null || !e.getMessage().contains("timed out")) {
                        throw (e);
                    }
                    failure_reason = "Timeout";
                }
            }
            if (failure_reason != null) {
                rootMap.put("failure reason", failure_reason.getBytes());
                rootMap.remove("files");
                byte[] data = BEncoder.encode(rootMap);
                message.write(data);
            }
        } finally {
            handler.closeSession();
        }
        return false;
    } finally {
        if (auth != null) {
            SESecurityManager.setPasswordAuthenticationOutcome(TRTrackerBTAnnouncerImpl.UDP_REALM, reqUrl, auth_ok);
        }
    }
}
Also used : PRUDPPacket(com.biglybt.net.udp.uc.PRUDPPacket) LogEvent(com.biglybt.core.logging.LogEvent) PRUDPPacketHandlerException(com.biglybt.net.udp.uc.PRUDPPacketHandlerException) PRUDPPacketHandler(com.biglybt.net.udp.uc.PRUDPPacketHandler)

Aggregations

LogEvent (com.biglybt.core.logging.LogEvent)2 PRUDPPacketHandlerException (com.biglybt.net.udp.uc.PRUDPPacketHandlerException)2 TRTrackerScraperResponseImpl (com.biglybt.core.tracker.client.impl.TRTrackerScraperResponseImpl)1 PRUDPPacket (com.biglybt.net.udp.uc.PRUDPPacket)1 PRUDPPacketHandler (com.biglybt.net.udp.uc.PRUDPPacketHandler)1 ClientIDException (com.biglybt.pif.clientid.ClientIDException)1 ByteArrayOutputStream (java.io.ByteArrayOutputStream)1 FileNotFoundException (java.io.FileNotFoundException)1 IOException (java.io.IOException)1