I2P Address: [http://git.idk.i2p]

Skip to content
Snippets Groups Projects

Compare revisions

Changes are shown as if the source revision was being merged into the target revision. Learn more about comparing revisions.

Source

Select target project
No results found

Target

Select target project
  • equincey/i2p.i2p
  • marek/i2p.i2p
  • kytv/i2p.i2p
  • agentoocat/i2p.i2p
  • aargh/i2p.i2p
  • Kalhintz/i2p.i2p
  • longyap/i2p.i2p
  • kelare/i2p.i2p
  • apsoyka/i2p.i2p
  • mesh/i2p.i2p
  • ashtod/i2p.i2p
  • y2kboy23/i2p.i2p
  • Lfrr/i2p.i2p
  • anonymousmaybe/i2p.i2p
  • obscuratus/i2p.i2p
  • zzz/i2p.i2p
  • lbt/i2p.i2p
  • 31337/i2p.i2p
  • DuncanIdaho/i2p.i2p
  • loveisgrief/i2p.i2p
  • i2p-hackers/i2p.i2p
  • thebland/i2p.i2p
  • elde/i2p.i2p
  • echelon/i2p.i2p
  • welshlyluvah1967/i2p.i2p
  • sadie/i2p.i2p
  • zlatinb/i2p.i2p
  • idk/i2p.i2p
  • pVT0/i2p.i2p
29 results
Show changes
Showing
with 1949 additions and 464 deletions
......@@ -55,7 +55,7 @@ import org.klomp.snark.dht.DHT;
/**
* Coordinates what peer does what.
*/
class PeerCoordinator implements PeerListener
class PeerCoordinator implements PeerListener, BandwidthListener
{
private final Log _log;
......@@ -73,7 +73,7 @@ class PeerCoordinator implements PeerListener
private final Snark snark;
// package local for access by CheckDownLoadersTask
final static long CHECK_PERIOD = 40*1000; // 40 seconds
final static long CHECK_PERIOD = 30*1000;
final static int MAX_UPLOADERS = 8;
public static final long MAX_INACTIVE = 8*60*1000;
public static final long MAX_SEED_INACTIVE = 2*60*1000;
......@@ -124,6 +124,12 @@ class PeerCoordinator implements PeerListener
/** Timer to handle all periodical tasks. */
private final CheckEvent timer;
// RerequestEvent and related values
private final SimpleTimer2.TimedEvent rerequestTimer;
private final Object rerequestLock = new Object();
private boolean wasRequestAllowed;
private boolean isRerequestScheduled;
private final byte[] id;
private final byte[] infohash;
......@@ -145,6 +151,7 @@ class PeerCoordinator implements PeerListener
private final MagnetState magnetState;
private final CoordinatorListener listener;
private final BandwidthListener bwListener;
private final I2PSnarkUtil _util;
private final RandomSource _random;
......@@ -163,7 +170,7 @@ class PeerCoordinator implements PeerListener
* @param storage null if in magnet mode
*/
public PeerCoordinator(I2PSnarkUtil util, byte[] id, byte[] infohash, MetaInfo metainfo, Storage storage,
CoordinatorListener listener, Snark torrent)
CoordinatorListener listener, Snark torrent, BandwidthListener bwl)
{
_util = util;
_random = util.getContext().random();
......@@ -174,6 +181,7 @@ class PeerCoordinator implements PeerListener
this.storage = storage;
this.listener = listener;
this.snark = torrent;
bwListener = bwl;
wantedPieces = new ArrayList<Piece>();
setWantedPieces();
......@@ -188,6 +196,9 @@ class PeerCoordinator implements PeerListener
timer = new CheckEvent(_util.getContext(), new PeerCheckerTask(_util, this));
timer.schedule((CHECK_PERIOD / 2) + _random.nextInt((int) CHECK_PERIOD));
// NOT scheduled until needed
rerequestTimer = new RerequestEvent();
// we don't store the last-requested time, so just delay a random amount
_commentsLastRequested.set(util.getContext().clock().now() - (COMMENT_REQ_INTERVAL - _random.nextLong(COMMENT_REQ_DELAY)));
}
......@@ -208,6 +219,42 @@ class PeerCoordinator implements PeerListener
}
}
/**
* Rerequest after unthrottled
* @since 0.9.62
*/
private class RerequestEvent extends SimpleTimer2.TimedEvent {
/** caller must schedule */
public RerequestEvent() {
super(_util.getContext().simpleTimer2());
}
public void timeReached() {
if (bwListener.shouldRequest(null, 0)) {
if (_log.shouldWarn())
_log.warn("Now unthrottled, rerequest timer poking all peers");
// so shouldRequest() won't fire us up again
synchronized(rerequestLock) {
wasRequestAllowed = true;
}
for (Peer p : peers) {
if (p.isInteresting() && !p.isChoked())
p.request();
}
synchronized(rerequestLock) {
isRerequestScheduled = false;
}
} else {
if (_log.shouldWarn())
_log.warn("Still throttled, rerequest timer reschedule");
synchronized(rerequestLock) {
wasRequestAllowed = false;
}
schedule(2*1000);
}
}
}
/**
* Only called externally from Storage after the double-check fails.
* Sets wantedBytes too.
......@@ -279,7 +326,6 @@ class PeerCoordinator implements PeerListener
/**
* Bytes not yet in storage. Does NOT account for skipped files.
* Not exact (does not adjust for last piece size).
* Returns how many bytes are still needed to get the complete torrent.
* @return -1 if in magnet mode
*/
......@@ -287,8 +333,13 @@ class PeerCoordinator implements PeerListener
{
if (metainfo == null | storage == null)
return -1;
// XXX - Only an approximation.
return ((long) storage.needed()) * metainfo.getPieceLength(0);
int psz = metainfo.getPieceLength(0);
long rv = ((long) storage.needed()) * psz;
int last = metainfo.getPieces() - 1;
BitField bf = storage.getBitField();
if (bf != null && !bf.get(last))
rv -= psz - metainfo.getPieceLength(last);
return rv;
}
/**
......@@ -324,6 +375,78 @@ class PeerCoordinator implements PeerListener
return downloaded.get();
}
/////// begin BandwidthListener interface ///////
/**
* Called when a peer has uploaded some bytes of a piece.
* @since 0.9.62 params changed
*/
public void uploaded(int size) {
uploaded.addAndGet(size);
bwListener.uploaded(size);
}
/**
* Called when a peer has downloaded some bytes of a piece.
* @since 0.9.62 params changed
*/
public void downloaded(int size) {
downloaded.addAndGet(size);
bwListener.downloaded(size);
}
/**
* Should we send this many bytes?
* Do NOT call uploaded() if this returns true.
* @since 0.9.62
*/
public boolean shouldSend(int size) {
boolean rv = bwListener.shouldSend(size);
if (rv)
uploaded.addAndGet(size);
return rv;
}
/**
* Should we request this many bytes?
* @since 0.9.62
*/
public boolean shouldRequest(Peer peer, int size) {
boolean rv;
synchronized(rerequestLock) {
rv = bwListener.shouldRequest(peer, size);
if (!wasRequestAllowed && rv) {
// we weren't allowed and now we are
if (isRerequestScheduled) {
// just let the timer run when scheduled, do not pull it in
// to prevent thrashing
//if (_log.shouldWarn())
// _log.warn("Now unthrottled, BUT DON'T reschedule rerequest timer");
} else {
// schedule the timer
// we still have to throw it to the timer so we don't loop
if (_log.shouldWarn())
_log.warn("Now unthrottled, schedule rerequest timer");
isRerequestScheduled = true;
// no rush, wait at little while
rerequestTimer.reschedule(1000);
}
wasRequestAllowed = true;
} else if (wasRequestAllowed && !rv) {
// we were allowed and now we aren't
if (!isRerequestScheduled) {
// schedule the timer
if (_log.shouldWarn())
_log.warn("Now throttled, schedule rerequest timer");
isRerequestScheduled = true;
rerequestTimer.schedule(3*1000);
}
wasRequestAllowed = false;
}
}
return rv;
}
/**
* Push the total uploaded/downloaded onto a RATE_DEPTH deep stack
*/
......@@ -398,6 +521,49 @@ class PeerCoordinator implements PeerListener
return rate / (factor * CHECK_PERIOD / 1000);
}
/**
* Current limit in Bps
* @since 0.9.62
*/
public long getUpBWLimit() {
return bwListener.getUpBWLimit();
}
/**
* Is snark as a whole over its limit?
*/
public boolean overUpBWLimit()
{
return bwListener.overUpBWLimit();
}
/**
* Is a particular peer who has downloaded this many bytes from us
* in the last CHECK_PERIOD over its limit?
*/
public boolean overUpBWLimit(long total)
{
return total * 1000 / CHECK_PERIOD > getUpBWLimit();
}
/**
* Current limit in Bps
* @since 0.9.62
*/
public long getDownBWLimit() {
return bwListener.getDownBWLimit();
}
/**
* Are we currently over the limit?
* @since 0.9.62
*/
public boolean overDownBWLimit() {
return bwListener.overDownBWLimit();
}
/////// end BandwidthListener interface ///////
public MetaInfo getMetaInfo()
{
return metainfo;
......@@ -448,18 +614,18 @@ class PeerCoordinator implements PeerListener
if (metainfo == null)
return 6;
int pieces = metainfo.getPieces();
if (pieces <= 2)
return 4;
if (pieces <= 5)
return 6;
//int size = metainfo.getPieceLength(0);
int max = _util.getMaxConnections();
// Now that we use temp files, no memory concern
//if (size <= 512*1024 || completed())
return max;
//if (size <= 1024*1024)
// return (max + max + 2) / 3;
//return (max + 2) / 3;
if (pieces <= 10) {
if (max > 4) max = 4;
} else if (pieces <= 25) {
if (max > 10) max = 10;
} else if (pieces <= 80) {
if (max > 16) max = 16;
}
long bwl = getDownBWLimit();
if (bwl < 32*1024)
max = Math.min(max, Math.max(6, (int) (I2PSnarkUtil.MAX_CONNECTIONS * bwl / (32*1024))));
return max;
}
public boolean halted() { return halted; }
......@@ -653,7 +819,7 @@ class PeerCoordinator implements PeerListener
{
public void run()
{
peer.runConnection(_util, listener, bitfield, magnetState, partialComplete);
peer.runConnection(_util, listener, PeerCoordinator.this, bitfield, magnetState, partialComplete);
}
};
String threadName = "Snark peer " + peer.toString();
......@@ -677,6 +843,8 @@ class PeerCoordinator implements PeerListener
{
if (storage == null || storage.getBitField().size() == 0)
return;
if (overUpBWLimit())
return;
// linked list will contain all interested peers that we choke.
// At the start are the peers that have us unchoked at the end the
......@@ -774,15 +942,6 @@ class PeerCoordinator implements PeerListener
*/
private static final int MAX_PARALLEL_REQUESTS = 4;
/**
* Returns one of pieces in the given BitField that is still wanted or
* -1 if none of the given pieces are wanted.
*/
public int wantPiece(Peer peer, BitField havePieces) {
Piece pc = wantPiece(peer, havePieces, true);
return pc != null ? pc.getId() : -1;
}
/**
* Returns one of pieces in the given BitField that is still wanted or
* null if none of the given pieces are wanted.
......@@ -999,28 +1158,6 @@ class PeerCoordinator implements PeerListener
}
}
/**
* Called when a peer has uploaded some bytes of a piece.
*/
public void uploaded(Peer peer, int size)
{
uploaded.addAndGet(size);
//if (listener != null)
// listener.peerChange(this, peer);
}
/**
* Called when a peer has downloaded some bytes of a piece.
*/
public void downloaded(Peer peer, int size)
{
downloaded.addAndGet(size);
//if (listener != null)
// listener.peerChange(this, peer);
}
/**
* Returns false if the piece is no good (according to the hash).
* In that case the peer that supplied the piece should probably be
......@@ -1155,7 +1292,7 @@ class PeerCoordinator implements PeerListener
}
if (uploaders.get() < allowedUploaders())
{
if(peer.isChoking())
if(peer.isChoking() && !overUpBWLimit())
{
uploaders.incrementAndGet();
interestedUploaders.incrementAndGet();
......@@ -1213,7 +1350,7 @@ class PeerCoordinator implements PeerListener
* Also mark the piece unrequested if this peer was the only one.
*
* @param peer partials, must include the zero-offset (empty) ones too.
* No dup pieces, piece.setDownloaded() must be set.
* No dup pieces.
* len field in Requests is ignored.
* @since 0.8.2
*/
......@@ -1231,14 +1368,14 @@ class PeerCoordinator implements PeerListener
synchronized(wantedPieces) {
for (Request req : partials) {
PartialPiece pp = req.getPartialPiece();
if (req.off > 0) {
if (pp.hasData()) {
// PartialPiece.equals() only compares piece number, which is what we want
int idx = partialPieces.indexOf(pp);
if (idx < 0) {
partialPieces.add(pp);
if (_log.shouldLog(Log.INFO))
_log.info("Saving orphaned partial piece (new) " + pp);
} else if (idx >= 0 && pp.getDownloaded() > partialPieces.get(idx).getDownloaded()) {
} else if (pp.getDownloaded() > partialPieces.get(idx).getDownloaded()) {
// replace what's there now
partialPieces.get(idx).release();
partialPieces.set(idx, pp);
......@@ -1295,7 +1432,9 @@ class PeerCoordinator implements PeerListener
for(Piece piece : wantedPieces) {
if (piece.getId() == savedPiece) {
if (peer.isCompleted() && piece.getPeerCount() > 1 &&
wantedPieces.size() > 2*END_GAME_THRESHOLD) {
wantedPieces.size() > 2*END_GAME_THRESHOLD &&
partialPieces.size() < 4 &&
_random.nextInt(4) != 0) {
// Try to preserve rarest-first
// by not requesting a partial piece that at least two non-seeders also have
// from a seeder
......@@ -1323,7 +1462,7 @@ class PeerCoordinator implements PeerListener
iter.remove();
piece.setRequested(peer, true);
if (_log.shouldLog(Log.INFO)) {
_log.info("Restoring orphaned partial piece " + pp +
_log.info("Restoring orphaned partial piece " + pp + " to " + peer +
" Partial list size now: " + partialPieces.size());
}
return pp;
......@@ -1435,7 +1574,9 @@ class PeerCoordinator implements PeerListener
}
}
} else if (id == ExtensionHandler.ID_HANDSHAKE) {
sendPeers(peer);
// We may not have the bitfield yet, but if we do, don't send PEX to seeds
if (!peer.isCompleted())
sendPeers(peer);
sendDHT(peer);
if (_util.utCommentsEnabled())
sendCommentReq(peer);
......@@ -1444,8 +1585,8 @@ class PeerCoordinator implements PeerListener
/**
* Send a PEX message to the peer, if he supports PEX.
* This just sends everybody we are connected to, we don't
* track new vs. old peers yet.
* This sends everybody we have connected to since the
* last time we sent PEX to him.
* @since 0.8.4
*/
void sendPeers(Peer peer) {
......@@ -1459,14 +1600,25 @@ class PeerCoordinator implements PeerListener
return;
try {
if (bev.getMap().get(ExtensionHandler.TYPE_PEX) != null) {
List<Peer> pList = peerList();
pList.remove(peer);
for (Iterator<Peer> iter = pList.iterator(); iter.hasNext(); ) {
if (iter.next().isWebPeer())
iter.remove();
List<Peer> pList = new ArrayList<Peer>();
long t = peer.getPexLastSent();
for (Peer p : peers) {
if (p.equals(peer))
continue;
if (p.isWebPeer())
continue;
if (p.getWhenConnected() > t)
pList.add(p);
}
if (!pList.isEmpty())
if (!pList.isEmpty()) {
ExtensionHandler.sendPEX(peer, pList);
peer.setPexLastSent(_util.getContext().clock().now());
//if (_log.shouldDebug())
// _log.debug("Pex: sent " + pList.size() + " new peers to " + peer);
//} else {
//if (_log.shouldDebug())
// _log.debug("Pex: no new peers to send to " + peer);
}
}
} catch (InvalidBEncodingException ibee) {}
}
......@@ -1734,27 +1886,6 @@ class PeerCoordinator implements PeerListener
interestedAndChoking.addAndGet(toAdd);
}
/**
* Is snark as a whole over its limit?
*/
public boolean overUpBWLimit()
{
if (listener != null)
return listener.overUpBWLimit();
return false;
}
/**
* Is a particular peer who has downloaded this many bytes from us
* in the last CHECK_PERIOD over its limit?
*/
public boolean overUpBWLimit(long total)
{
if (listener != null)
return listener.overUpBWLimit(total * 1000 / CHECK_PERIOD);
return false;
}
/**
* Convenience
* @since 0.9.2
......
......@@ -120,36 +120,6 @@ interface PeerListener
*/
ByteArray gotRequest(Peer peer, int piece, int off, int len);
/**
* Called when a (partial) piece has been downloaded from the peer.
*
* @param peer the Peer from which size bytes where downloaded.
* @param size the number of bytes that where downloaded.
*/
void downloaded(Peer peer, int size);
/**
* Called when a (partial) piece has been uploaded to the peer.
*
* @param peer the Peer to which size bytes where uploaded.
* @param size the number of bytes that where uploaded.
*/
void uploaded(Peer peer, int size);
/**
* Called when we are downloading from the peer and need to ask for
* a new piece. Might be called multiple times before
* <code>gotPiece()</code> is called.
*
* @param peer the Peer that will be asked to provide the piece.
* @param bitfield a BitField containing the pieces that the other
* side has.
*
* @return one of the pieces from the bitfield that we want or -1 if
* we are no longer interested in the peer.
*/
int wantPiece(Peer peer, BitField bitfield);
/**
* Called when we are downloading from the peer and may need to ask for
* a new piece. Returns true if wantPiece() or getPartialPiece() would return a piece.
......
......@@ -41,6 +41,7 @@ class PeerState implements DataLoader
private final Peer peer;
/** Fixme, used by Peer.disconnect() to get to the coordinator */
final PeerListener listener;
private final BandwidthListener bwListener;
/** Null before we have it. locking: this */
private MetaInfo metainfo;
/** Null unless needed. Contains -1 for all. locking: this */
......@@ -66,7 +67,8 @@ class PeerState implements DataLoader
// Outstanding request
private final List<Request> outstandingRequests = new ArrayList<Request>();
/** the tail (NOT the head) of the request queue */
private Request lastRequest = null;
private Request lastRequest;
private int currentMaxPipeline;
// FIXME if piece size < PARTSIZE, pipeline could be bigger
/** @since 0.9.47 */
......@@ -81,17 +83,23 @@ class PeerState implements DataLoader
/**
* @param metainfo null if in magnet mode
*/
PeerState(Peer peer, PeerListener listener, MetaInfo metainfo,
PeerState(Peer peer, PeerListener listener, BandwidthListener bwl, MetaInfo metainfo,
PeerConnectionIn in, PeerConnectionOut out)
{
this.peer = peer;
this.listener = listener;
bwListener = bwl;
this.metainfo = metainfo;
this.in = in;
this.out = out;
}
/**
* @since 0.9.62
*/
BandwidthListener getBandwidthListener() { return bwListener; }
// NOTE Methods that inspect or change the state synchronize (on this).
void keepAliveMessage()
......@@ -389,7 +397,6 @@ class PeerState implements DataLoader
void uploaded(int size)
{
peer.uploaded(size);
listener.uploaded(peer, size);
}
// This is used to flag that we have to back up from the firstOutstandingRequest
......@@ -408,8 +415,8 @@ class PeerState implements DataLoader
void pieceMessage(Request req)
{
int size = req.len;
peer.downloaded(size);
listener.downloaded(peer, size);
// Now reported byte-by-byte in PartialPiece
//peer.downloaded(size);
if (_log.shouldLog(Log.DEBUG))
_log.debug("got end of Chunk("
......@@ -417,11 +424,12 @@ class PeerState implements DataLoader
+ peer);
// Last chunk needed for this piece?
// FIXME if priority changed to skip, we will think we're done when we aren't
if (getFirstOutstandingRequest(req.getPiece()) == -1)
PartialPiece pp = req.getPartialPiece();
boolean complete = pp.isComplete();
if (complete)
{
// warning - may block here for a while
if (listener.gotPiece(peer, req.getPartialPiece()))
if (listener.gotPiece(peer, pp))
{
if (_log.shouldLog(Log.DEBUG))
_log.debug("Got " + req.getPiece() + ": " + peer);
......@@ -442,9 +450,31 @@ class PeerState implements DataLoader
synchronized(this) {
pendingRequest = null;
}
// getOutstandingRequest() was called by PeerConnectionIn at the start of the chunk;
// if the bandwidth limiter throttled us to zero requests then, try again now
if (outstandingRequests.isEmpty()) {
addRequest();
if (!complete) {
synchronized(this) {
if (outstandingRequests.isEmpty()) {
// we MUST return the partial piece to PeerCoordinator,
// or else we will lose it and leak the data
if (_log.shouldWarn())
_log.warn("Throttled, returned to coord. w/ data " + req);
List<Request> pcs = Collections.singletonList(req);
listener.savePartialPieces(this.peer, pcs);
lastRequest = null;
}
}
}
}
}
/**
* TODO this is how we tell we got all the chunks in pieceMessage() above.
*
*
* @return index in outstandingRequests or -1
*/
synchronized private int getFirstOutstandingRequest(int piece)
......@@ -567,15 +597,8 @@ class PeerState implements DataLoader
List<Request> rv = new ArrayList<Request>(pcs.size());
for (Integer p : pcs) {
Request req = getLowestOutstandingRequest(p.intValue());
if (req != null) {
PartialPiece pp = req.getPartialPiece();
synchronized(pp) {
int dl = pp.getDownloaded();
if (req.off != dl)
req = new Request(pp, dl);
}
if (req != null)
rv.add(req);
}
}
outstandingRequests.clear();
pendingRequest = null;
......@@ -699,12 +722,6 @@ class PeerState implements DataLoader
/**
* BEP 6
* If the peer rejects lower chunks but not higher ones, thus creating holes,
* we won't figure it out and the piece will fail, since we don't currently
* keep a chunk bitmap in PartialPiece.
* As long as the peer rejects all the chunks, or rejects only the last chunks,
* no holes are created and we will be fine. The reject messages may be in any order,
* just don't make a hole when it's over.
*
* @since 0.9.21
*/
......@@ -728,19 +745,10 @@ class PeerState implements DataLoader
}
}
if (deletedRequest != null && !haveMoreRequests) {
// We must return the piece to the coordinator
// Create a new fake request so we can set the offset correctly
PartialPiece pp = deletedRequest.getPartialPiece();
int downloaded = pp.getDownloaded();
Request req;
if (deletedRequest.off == downloaded)
req = deletedRequest;
else
req = new Request(pp, downloaded, 1);
List<Request> pcs = Collections.singletonList(req);
List<Request> pcs = Collections.singletonList(deletedRequest);
listener.savePartialPieces(this.peer, pcs);
if (_log.shouldWarn())
_log.warn("Returned to coord. w/ offset " + pp.getDownloaded() + " due to reject(" + piece + ',' + begin + ',' + length + ") from " + peer);
_log.warn("Returned to coord. w/ data " + deletedRequest.getPartialPiece().getDownloaded() + " due to reject(" + piece + ',' + begin + ',' + length + ") from " + peer);
}
if (lastRequest != null && lastRequest.getPiece() == piece &&
lastRequest.off == begin && lastRequest.len == length)
......@@ -866,72 +874,108 @@ class PeerState implements DataLoader
*
* This is called from several places:
*<pre>
* By getOustandingRequest() when the first part of a chunk comes in
* By getOutstandingRequest() when the first part of a chunk comes in
* By havePiece() when somebody got a new piece completed
* By chokeMessage() when we receive an unchoke
* By setInteresting() when we are now interested
* By PeerCoordinator.updatePiecePriorities()
*</pre>
*/
synchronized void addRequest()
void addRequest()
{
// no bitfield yet? nothing to request then.
if (bitfield == null)
return;
if (metainfo == null)
return;
boolean more_pieces = true;
while (more_pieces)
{
more_pieces = outstandingRequests.size() < peer.getMaxPipeline();
// We want something and we don't have outstanding requests?
if (more_pieces && lastRequest == null) {
// we have nothing in the queue right now
if (!interesting) {
// If we need something, set interesting but delay pulling
// a request from the PeerCoordinator until unchoked.
if (listener.needPiece(this.peer, bitfield)) {
setInteresting(true);
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " addRequest() we need something, setting interesting, delaying requestNextPiece()");
} else {
// Initial bw check. We do the actual accounting in PeerConnectionOut.
// Implement a simple AIMD slow-start on the request queue size with
// currentMaxPipeline counter.
// Avoid cross-peer deadlocks from PeerCoordinator, call this outside the lock
if (!bwListener.shouldRequest(peer, 0)) {
synchronized(this) {
// Due to changes elsewhere we can let this go down to zero now
currentMaxPipeline /= 2;
}
if (_log.shouldWarn())
_log.warn(peer + " throttle request, interesting? " + interesting + " choked? " + choked +
" reqq: " + outstandingRequests.size() + " maxp: " + currentMaxPipeline);
return;
}
synchronized(this) {
// adjust currentMaxPipeline
long rate = bwListener.getDownloadRate();
long limit = bwListener.getDownBWLimit();
if (rate < limit * 7 / 10) {
if (currentMaxPipeline < peer.getMaxPipeline())
currentMaxPipeline++;
} else if (rate > limit * 9 / 10) {
currentMaxPipeline = 1;
} else if (currentMaxPipeline < 2) {
currentMaxPipeline++;
}
boolean more_pieces = true;
while (more_pieces)
{
more_pieces = outstandingRequests.size() < currentMaxPipeline;
// We want something and we don't have outstanding requests?
if (more_pieces && lastRequest == null) {
// we have nothing in the queue right now
if (!interesting) {
// If we need something, set interesting but delay pulling
// a request from the PeerCoordinator until unchoked.
if (listener.needPiece(this.peer, bitfield)) {
setInteresting(true);
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " addRequest() we need something, setting interesting, delaying requestNextPiece()");
} else {
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " addRequest() needs nothing");
}
return;
}
if (choked) {
// If choked, delay pulling
// a request from the PeerCoordinator until unchoked.
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " addRequest() needs nothing");
_log.debug(peer + " addRequest() we are choked, delaying requestNextPiece()");
return;
}
return;
}
if (choked) {
// If choked, delay pulling
// a request from the PeerCoordinator until unchoked.
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " addRequest() we are choked, delaying requestNextPiece()");
return;
}
// huh? rv unused
more_pieces = requestNextPiece();
} else if (more_pieces) // We want something
{
int pieceLength;
boolean isLastChunk;
pieceLength = metainfo.getPieceLength(lastRequest.getPiece());
isLastChunk = lastRequest.off + lastRequest.len == pieceLength;
// Last part of a piece?
if (isLastChunk)
more_pieces = requestNextPiece();
else
} else if (more_pieces) // We want something
{
int pieceLength;
boolean isLastChunk;
pieceLength = metainfo.getPieceLength(lastRequest.getPiece());
isLastChunk = lastRequest.off + lastRequest.len == pieceLength;
// Last part of a piece?
if (isLastChunk) {
more_pieces = requestNextPiece();
} else {
PartialPiece nextPiece = lastRequest.getPartialPiece();
int nextBegin = lastRequest.off + PARTSIZE;
int maxLength = pieceLength - nextBegin;
int nextLength = maxLength > PARTSIZE ? PARTSIZE
: maxLength;
Request req
= new Request(nextPiece,nextBegin, nextLength);
outstandingRequests.add(req);
if (!choked)
out.sendRequest(req);
lastRequest = req;
while (true) {
// don't rerequest chunks we already have
if (!nextPiece.hasChunk(nextBegin / PARTSIZE)) {
int maxLength = pieceLength - nextBegin;
int nextLength = maxLength > PARTSIZE ? PARTSIZE
: maxLength;
Request req = new Request(nextPiece,nextBegin, nextLength);
outstandingRequests.add(req);
if (!choked)
out.sendRequest(req);
lastRequest = req;
break;
} else {
nextBegin += PARTSIZE;
if (nextBegin >= pieceLength) {
more_pieces = requestNextPiece();
break;
}
}
}
}
}
}
}
......@@ -972,47 +1016,6 @@ class PeerState implements DataLoader
pp.release();
}
}
/******* getPartialPiece() does it all now
// Note that in addition to the bitfield, PeerCoordinator uses
// its request tracking and isRequesting() to determine
// what piece to give us next.
int nextPiece = listener.wantPiece(peer, bitfield);
if (nextPiece != -1
&& (lastRequest == null || lastRequest.getPiece() != nextPiece)) {
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " want piece " + nextPiece);
// Fail safe to make sure we are interested
// When we transition into the end game we may not be interested...
if (!interesting) {
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " transition to end game, setting interesting");
interesting = true;
out.sendInterest(true);
}
int piece_length = metainfo.getPieceLength(nextPiece);
//Catch a common place for OOMs esp. on 1MB pieces
byte[] bs;
try {
bs = new byte[piece_length];
} catch (OutOfMemoryError oom) {
_log.warn("Out of memory, can't request piece " + nextPiece, oom);
return false;
}
int length = Math.min(piece_length, PARTSIZE);
Request req = new Request(nextPiece, bs, 0, length);
outstandingRequests.add(req);
if (!choked)
out.sendRequest(req);
lastRequest = req;
return true;
} else {
if (_log.shouldLog(Log.DEBUG))
_log.debug(peer + " no more pieces to request");
}
*******/
}
// failsafe
......
......@@ -74,8 +74,8 @@ class Request
/**
* @since 0.9.1
*/
public void read(DataInputStream din) throws IOException {
piece.read(din, off, len);
public void read(DataInputStream din, BandwidthListener bwl) throws IOException {
piece.read(din, off, len, bwl);
}
/**
......
......@@ -252,7 +252,7 @@ public class Snark
/**
* from main() via parseArguments() single torrent
*
* @deprecated unused
* unused
*/
/****
Snark(I2PSnarkUtil util, String torrent, String ip, int user_port,
......@@ -264,7 +264,7 @@ public class Snark
/**
* single torrent - via router
*
* @deprecated unused
* unused
*/
/****
public Snark(I2PAppContext ctx, Properties opts, String torrent,
......@@ -608,7 +608,7 @@ public class Snark
if (_log.shouldLog(Log.INFO))
_log.info("Starting PeerCoordinator, ConnectionAcceptor, and TrackerClient");
activity = "Collecting pieces";
coordinator = new PeerCoordinator(_util, id, infoHash, meta, storage, this, this);
coordinator = new PeerCoordinator(_util, id, infoHash, meta, storage, this, this, completeListener.getBandwidthListener());
coordinator.setUploaded(savedUploaded);
if (_peerCoordinatorSet != null) {
// multitorrent
......@@ -1259,6 +1259,8 @@ public class Snark
*/
private void fatalRouter(String s, Throwable t) throws RouterException {
_log.error(s, t);
if (!_util.getContext().isRouterContext())
System.out.println(s);
stopTorrent(true);
if (completeListener != null)
completeListener.fatal(this, s);
......@@ -1333,6 +1335,9 @@ public class Snark
*/
public void replaceMetaInfo(MetaInfo metainfo) {
meta = metainfo;
TrackerClient tc = trackerclient;
if (tc != null)
tc.reinitialize();
}
///////////// Begin StorageListener methods
......@@ -1465,31 +1470,6 @@ public class Snark
return totalUploaders > limit;
}
/**
* Is i2psnark as a whole over its limit?
*/
public boolean overUpBWLimit() {
if (_peerCoordinatorSet == null)
return false;
long total = 0;
for (PeerCoordinator c : _peerCoordinatorSet) {
if (!c.halted())
total += c.getCurrentUploadRate();
}
long limit = 1024l * _util.getMaxUpBW();
if (_log.shouldLog(Log.INFO))
_log.info("Total up bw: " + total + " Limit: " + limit);
return total > limit;
}
/**
* Is a particular peer who has this recent download rate (in Bps) over our upstream bandwidth limit?
*/
public boolean overUpBWLimit(long total) {
long limit = 1024l * _util.getMaxUpBW();
return total > limit;
}
/**
* A unique ID for this torrent, useful for RPC
* @return positive value unless you wrap around
......
......@@ -25,10 +25,12 @@ import java.util.Set;
import java.util.StringTokenizer;
import java.util.concurrent.ConcurrentHashMap;
import net.i2p.CoreVersion;
import net.i2p.I2PAppContext;
import net.i2p.app.ClientApp;
import net.i2p.app.ClientAppManager;
import net.i2p.app.ClientAppState;
import net.i2p.app.NavService;
import net.i2p.app.NotificationService;
import net.i2p.client.I2PClient;
import net.i2p.client.streaming.I2PSocketManager.DisconnectListener;
......@@ -43,6 +45,7 @@ import net.i2p.util.FileUtil;
import net.i2p.util.I2PAppThread;
import net.i2p.util.Log;
import net.i2p.util.OrderedProperties;
import net.i2p.util.PortMapper;
import net.i2p.util.SecureDirectory;
import net.i2p.util.SecureFileOutputStream;
import net.i2p.util.SimpleTimer;
......@@ -85,8 +88,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
private final Log _log;
private final UIMessages _messages;
private final I2PSnarkUtil _util;
private PeerCoordinatorSet _peerCoordinatorSet;
private ConnectionAcceptor _connectionAcceptor;
private final PeerCoordinatorSet _peerCoordinatorSet;
private final ConnectionAcceptor _connectionAcceptor;
private final BandwidthManager _bwManager;
private Thread _monitor;
private volatile boolean _running;
private volatile boolean _stopping;
......@@ -102,6 +106,8 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
//public static final String PROP_EEP_PORT = "i2psnark.eepPort";
public static final String PROP_UPLOADERS_TOTAL = "i2psnark.uploaders.total";
public static final String PROP_UPBW_MAX = "i2psnark.upbw.max";
/** @since 0.9.62 */
public static final String PROP_DOWNBW_MAX = "i2psnark.downbw.max";
public static final String PROP_DIR = "i2psnark.dir";
private static final String PROP_META_PREFIX = "i2psnark.zmeta.";
private static final String PROP_META_RUNNING = "running";
......@@ -127,7 +133,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
private static final String PROP_META_ACTIVITY = "activity";
private static final String CONFIG_FILE_SUFFIX = ".config";
private static final String CONFIG_FILE = "i2psnark" + CONFIG_FILE_SUFFIX;
public static final String CONFIG_FILE = "i2psnark" + CONFIG_FILE_SUFFIX;
private static final String COMMENT_FILE_SUFFIX = ".comments.txt.gz";
public static final String PROP_FILES_PUBLIC = "i2psnark.filesPublic";
public static final String PROP_OLD_AUTO_START = "i2snark.autoStart"; // oops
......@@ -162,17 +168,25 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
private static final String PROP_COMMENTS = "i2psnark.comments";
/** @since 0.9.31 */
private static final String PROP_COMMENTS_NAME = "i2psnark.commentsName";
/** @since 0.9.58 */
public static final String PROP_MAX_FILES_PER_TORRENT = "i2psnark.maxFilesPerTorrent";
public static final int MIN_UP_BW = 10;
public static final int MIN_UP_BW = 5;
public static final int MIN_DOWN_BW = 2 * MIN_UP_BW;
public static final int DEFAULT_MAX_UP_BW = 25;
private static final int DEFAULT_MAX_DOWN_BW = 200;
public static final int DEFAULT_STARTUP_DELAY = 3;
public static final int DEFAULT_REFRESH_DELAY_SECS = 15;
private static final int DEFAULT_PAGE_SIZE = 50;
public static final int DEFAULT_TUNNEL_QUANTITY = 3;
public static final int DEFAULT_MAX_FILES_PER_TORRENT = 2000;
public static final String CONFIG_DIR_SUFFIX = ".d";
private static final String SUBDIR_PREFIX = "s";
private static final String B64 = Base64.ALPHABET_I2P;
private static final int MAX_MESSAGES = 100;
private static final String EXTRA = "";
/** @since 0.9.58 */
public static final String FULL_VERSION = CoreVersion.VERSION + EXTRA;
/**
* "name", "announceURL=websiteURL" pairs
......@@ -229,7 +243,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
// psi go - unregistered
"uajd4nctepxpac4c4bdyrdw7qvja2a5u3x25otfhkptcjgd53ioq.b32.i2p",
// Vuze - unregistered
"crs2nugpvoqygnpabqbopwyjqettwszth6ubr2fh7whstlos3a6q.b32.i2p"
"crs2nugpvoqygnpabqbopwyjqettwszth6ubr2fh7whstlos3a6q.b32.i2p",
"opentracker.r4sas.i2p", "punzipidirfqspstvzpj6gb4tkuykqp6quurj6e23bgxcxhdoe7q.b32.i2p",
"opentracker.skank.i2p", "by7luzwhx733fhc5ug2o75dcaunblq2ztlshzd7qvptaoa73nqua.b32.i2p"
}));
static {
......@@ -271,6 +287,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
_log = _context.logManager().getLog(SnarkManager.class);
_messages = new UIMessages(MAX_MESSAGES);
_util = new I2PSnarkUtil(_context, ctxName, this);
_peerCoordinatorSet = new PeerCoordinatorSet();
_connectionAcceptor = new ConnectionAcceptor(_util, _peerCoordinatorSet);
_bwManager = new BandwidthManager(ctx, DEFAULT_MAX_UP_BW * 1024, DEFAULT_MAX_DOWN_BW * 1024);
DEFAULT_AUTO_START = !ctx.isRouterContext();
String cfile = ctxName + CONFIG_FILE_SUFFIX;
File configFile = new File(cfile);
......@@ -289,15 +308,22 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
*/
public void start() {
_running = true;
ClientAppManager cmgr = _context.clientAppManager();
if ("i2psnark".equals(_contextName)) {
// Register with the ClientAppManager so the rpc plugin can find us
// only if default instance
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null)
cmgr.register(this);
} else {
// Register link with NavHelper
if (cmgr != null) {
NavService nav = (NavService) cmgr.getRegisteredApp("NavHelper");
if (nav != null) {
String name = DataHelper.stripHTML(_contextPath.substring(1));
nav.registerApp(name, name, _contextPath, null, "/themes/console/images/i2psnark.png");
}
}
}
_peerCoordinatorSet = new PeerCoordinatorSet();
_connectionAcceptor = new ConnectionAcceptor(_util, _peerCoordinatorSet);
_monitor = new I2PAppThread(new DirMonitor(), "Snark DirMonitor", true);
_monitor.start();
// only if default instance
......@@ -377,11 +403,20 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
_connectionAcceptor.halt();
_idleChecker.cancel();
stopAllTorrents(true);
ClientAppManager cmgr = _context.clientAppManager();
if ("i2psnark".equals(_contextName)) {
// only if default instance
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null)
cmgr.unregister(this);
} else {
// Unregister link with NavHelper
if (cmgr != null) {
NavService nav = (NavService) cmgr.getRegisteredApp("NavHelper");
if (nav != null) {
String name = DataHelper.stripHTML(_contextPath.substring(1));
nav.unregisterApp(name);
}
}
}
if (_log.shouldWarn())
_log.warn("Snark stop() end");
......@@ -433,6 +468,14 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
/** hook to I2PSnarkUtil for the servlet */
public I2PSnarkUtil util() { return _util; }
/**
* The BandwidthManager.
* @since 0.9.62
*/
public BandwidthListener getBandwidthListener() {
return _bwManager;
}
/**
* Use if it does not include a link.
* Escapes '&lt;' and '&gt;' before queueing
......@@ -459,7 +502,10 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
/** @since 0.9 */
public void clearMessages() {
_messages.clear();
_messages.clear();
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null)
cmgr.setBubble(PortMapper.SVC_I2PSNARK, 0, null);
}
/**
......@@ -467,7 +513,10 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
* @since 0.9.33
*/
public void clearMessages(int id) {
_messages.clearThrough(id);
_messages.clearThrough(id);
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null)
cmgr.setBubble(PortMapper.SVC_I2PSNARK, 0, null);
}
/**
......@@ -701,7 +750,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
File conf = configFile(_configDir, ih);
synchronized(_configLock) { // one lock for all
try {
DataHelper.loadProps(rv, conf);
I2PSnarkUtil.loadProps(rv, conf);
} catch (IOException ioe) {}
}
return rv;
......@@ -942,13 +991,21 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
* @return true if we got a response from the router
*/
private boolean getBWLimit() {
boolean shouldSet = !_config.containsKey(PROP_UPBW_MAX);
if (shouldSet || !_context.isRouterContext()) {
int[] limits = BWLimits.getBWLimits(_util.getI2CPHost(), _util.getI2CPPort());
if (limits == null)
return false;
if (shouldSet && limits[1] > 0)
_util.setMaxUpBW(limits[1]);
int[] limits = BWLimits.getBWLimits(_util.getI2CPHost(), _util.getI2CPPort());
if (limits == null)
return false;
int up = limits[1];
if (up > 0) {
int maxup = getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW);
if (maxup > up)
maxup = up;
_util.setMaxUpBW(maxup);
_bwManager.setUpBWLimit(maxup * 1000L);
}
int down = limits[0];
if (down > 0) {
int maxdown = getInt(PROP_DOWNBW_MAX, DEFAULT_MAX_DOWN_BW);
_bwManager.setDownBWLimit(Math.min(down, maxdown) * 1000L);
}
return true;
}
......@@ -977,6 +1034,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
// _util.setProxy(eepHost, eepPort);
_util.setMaxUploaders(getInt(PROP_UPLOADERS_TOTAL, Snark.MAX_TOTAL_UPLOADERS));
_util.setMaxUpBW(getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW));
_util.setMaxFilesPerTorrent(getInt(PROP_MAX_FILES_PER_TORRENT, DEFAULT_MAX_FILES_PER_TORRENT));
_util.setStartupDelay(getInt(PROP_STARTUP_DELAY, DEFAULT_STARTUP_DELAY));
_util.setFilesPublic(areFilesPublic());
_util.setOpenTrackers(getListConfig(PROP_OPENTRACKERS, DEFAULT_OPENTRACKERS));
......@@ -1019,13 +1077,13 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
public void updateConfig(String dataDir, boolean filesPublic, boolean autoStart, boolean smartSort, String refreshDelay,
String startDelay, String pageSize, String seedPct, String eepHost,
String eepPort, String i2cpHost, String i2cpPort, String i2cpOpts,
String upLimit, String upBW, boolean useOpenTrackers, boolean useDHT, String theme,
String upLimit, String upBW, String downBW, boolean useOpenTrackers, boolean useDHT, String theme,
String lang, boolean enableRatings, boolean enableComments, String commentName, boolean collapsePanels) {
synchronized(_configLock) {
locked_updateConfig(dataDir, filesPublic, autoStart, smartSort, refreshDelay,
startDelay, pageSize, seedPct, eepHost,
eepPort, i2cpHost, i2cpPort, i2cpOpts,
upLimit, upBW, useOpenTrackers, useDHT, theme,
upLimit, upBW, downBW, useOpenTrackers, useDHT, theme,
lang, enableRatings, enableComments, commentName, collapsePanels);
}
}
......@@ -1033,7 +1091,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
private void locked_updateConfig(String dataDir, boolean filesPublic, boolean autoStart, boolean smartSort, String refreshDelay,
String startDelay, String pageSize, String seedPct, String eepHost,
String eepPort, String i2cpHost, String i2cpPort, String i2cpOpts,
String upLimit, String upBW, boolean useOpenTrackers, boolean useDHT, String theme,
String upLimit, String upBW, String downBW, boolean useOpenTrackers, boolean useDHT, String theme,
String lang, boolean enableRatings, boolean enableComments, String commentName, boolean collapsePanels) {
boolean changed = false;
boolean interruptMonitor = false;
......@@ -1071,6 +1129,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
if ( limit != _util.getMaxUpBW()) {
if ( limit >= MIN_UP_BW ) {
_util.setMaxUpBW(limit);
_bwManager.setUpBWLimit(limit * 1000L);
changed = true;
_config.setProperty(PROP_UPBW_MAX, Integer.toString(limit));
addMessage(_t("Up BW limit changed to {0}KBps", limit));
......@@ -1079,6 +1138,20 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
}
}
}
if (downBW != null) {
int limit = (int) (_bwManager.getDownBWLimit() / 1024);
try { limit = Integer.parseInt(downBW.trim()); } catch (NumberFormatException nfe) {}
if ( limit != _bwManager.getDownBWLimit()) {
if ( limit >= MIN_DOWN_BW ) {
_bwManager.setDownBWLimit(limit * 1000L);
changed = true;
_config.setProperty(PROP_DOWNBW_MAX, Integer.toString(limit));
addMessage(_t("Down BW limit changed to {0}KBps", limit));
} else {
addMessage(_t("Minimum down bandwidth limit is {0}KBps", MIN_DOWN_BW));
}
}
}
if (startDelay != null && _context.isRouterContext()) {
int minutes = _util.getStartupDelay();
......@@ -1135,7 +1208,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
if (dataDir != null && !dataDir.equals(getDataDir().getAbsolutePath())) {
dataDir = DataHelper.stripHTML(dataDir.trim());
File dd = areFilesPublic() ? new File(dataDir) : new SecureDirectory(dataDir);
if (!dd.isAbsolute()) {
if (_util.connected()) {
addMessage(_t("Stop all torrents before changing data directory"));
} else if (!dd.isAbsolute()) {
addMessage(_t("Data directory must be an absolute path") + ": " + dataDir);
} else if (!dd.exists() && !dd.mkdirs()) {
// save this tag for now, may need it again
......@@ -1151,10 +1226,16 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
addMessage(_t("No write permissions for data directory") + ": " + dataDir);
changed = true;
interruptMonitor = true;
_config.setProperty(PROP_DIR, dataDir);
synchronized (_snarks) {
for (Snark snark : _snarks.values()) {
// leave magnets alone, remove everything else
if (snark.getMetaInfo() != null)
stopTorrent(snark, true);
}
_config.setProperty(PROP_DIR, dataDir);
}
addMessage(_t("Data directory changed to {0}", dataDir));
}
}
// Standalone (app context) language.
......@@ -1232,7 +1313,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
Properties p = new Properties();
p.putAll(opts);
_util.setI2CPConfig(i2cpHost, port, p);
_util.setMaxUpBW(getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW));
int max = getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW);
_util.setMaxUpBW(max);
_bwManager.setUpBWLimit(max * 1000);
addMessage(_t("I2CP and tunnel changes will take effect after stopping all torrents"));
} else if (!reconnect) {
// The usual case, the other two are if not in router context
......@@ -1247,7 +1330,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
}
addMessage(_t("I2CP settings changed to {0}", i2cpHost + ':' + port + ' ' + i2cpOpts));
_util.setI2CPConfig(i2cpHost, port, opts);
_util.setMaxUpBW(getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW));
int max = getInt(PROP_UPBW_MAX, DEFAULT_MAX_UP_BW);
_util.setMaxUpBW(max);
_bwManager.setUpBWLimit(max * 1000);
boolean ok = _util.connect();
if (!ok) {
addMessage(_t("Unable to connect with the new settings, reverting to the old I2CP settings"));
......@@ -1456,9 +1541,6 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
}
}
/** hardcoded for sanity. perhaps this should be customizable, for people who increase their ulimit, etc. */
public static final int MAX_FILES_PER_TORRENT = 2000;
/**
* Set of canonical .torrent filenames that we are dealing with.
* An unsynchronized copy.
......@@ -1718,21 +1800,31 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
String link = linkify(torrent);
if (!dontAutoStart && shouldAutoStart() && running) {
if (!_util.connected()) {
addMessage(_t("Connecting to I2P"));
String msg = _t("Connecting to I2P");
addMessage(msg);
if (!_context.isRouterContext())
System.out.println(msg);
boolean ok = _util.connect();
if (!ok) {
if (_context.isRouterContext())
if (_context.isRouterContext()) {
addMessage(_t("Unable to connect to I2P"));
else
addMessage(_t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort());
} else {
msg = _t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort();
addMessage(msg);
System.out.println(msg);
}
// this would rename the torrent to .BAD
//return false;
}
}
torrent.startTorrent();
addMessageNoEscape(_t("Torrent added and started: {0}", link));
if (!_context.isRouterContext())
System.out.println(_t("Torrent added and started: {0}", torrent.getBaseName()));
} else {
addMessageNoEscape(_t("Torrent added: {0}", link));
if (!_context.isRouterContext())
System.out.println(_t("Torrent added: {0}", torrent.getBaseName()));
}
return true;
}
......@@ -2275,7 +2367,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
if (!subdir.exists())
subdir.mkdirs();
try {
DataHelper.storeProps(config, conf);
I2PSnarkUtil.storeProps(config, conf);
if (_log.shouldInfo())
_log.info("Saved config to " + conf /* , new Exception() */ );
} catch (IOException ioe) {
......@@ -2417,8 +2509,11 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
*/
private String validateTorrent(MetaInfo info) {
List<List<String>> files = info.getFiles();
if ( (files != null) && (files.size() > MAX_FILES_PER_TORRENT) ) {
return _t("Too many files in \"{0}\" ({1})!", info.getName(), files.size());
if (files != null && files.size() > _util.getMaxFilesPerTorrent()) {
return _t("Too many files in \"{0}\" ({1})!", info.getName(), files.size()) +
" - limit is " + _util.getMaxFilesPerTorrent() + ", zip them or set " +
PROP_MAX_FILES_PER_TORRENT + '=' + files.size() + " in " +
_configFile.getAbsolutePath() + " and restart";
} else if ( (files == null) && (info.getName().endsWith(".torrent")) ) {
return _t("Torrent file \"{0}\" cannot end in \".torrent\"!", info.getName());
} else if (info.getPieces() <= 0) {
......@@ -2537,6 +2632,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
try { Thread.sleep(delay); } catch (InterruptedException ie) {}
// Remove that first message
_messages.clearThrough(id);
} else if (_context.isRouterContext()) {
// to wait for client manager to be up so we can get bandwidth limits
try { Thread.sleep(3000); } catch (InterruptedException ie) {}
}
// here because we need to delay until I2CP is up
......@@ -2554,6 +2652,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
// Test if the router is there
// For standalone, this will probe the router every 60 seconds if not connected
boolean oldOK = routerOK;
// standalone, first time only
if (doMagnets && !_context.isRouterContext())
dtgNotify(Log.INFO, _t("Connecting to I2P") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort());
routerOK = getBWLimit();
if (routerOK) {
autostart = shouldAutoStart();
......@@ -2564,17 +2665,29 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
String prop = config.getProperty(PROP_META_RUNNING);
if (prop == null || Boolean.parseBoolean(prop)) {
if (!_util.connected()) {
addMessage(_t("Connecting to I2P"));
String msg = _t("Connecting to I2P");
addMessage(msg);
if (!_context.isRouterContext())
dtgNotify(Log.INFO, msg + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort());
// getBWLimit() was successful so this should work
boolean ok = _util.connect();
if (!ok) {
if (_context.isRouterContext())
if (_context.isRouterContext()) {
addMessage(_t("Unable to connect to I2P"));
else
addMessage(_t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort());
} else {
msg = _t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort();
addMessage(msg);
dtgNotify(Log.ERROR, msg);
}
routerOK = false;
autostart = false;
break;
} else {
if (!_context.isRouterContext()) {
msg = "Connected to I2P at " + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort();
addMessage(msg);
dtgNotify(Log.INFO, msg);
}
}
}
addMessageNoEscape(_t("Starting up torrent {0}", linkify(snark)));
......@@ -2589,7 +2702,8 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
}
}
if (routerOK)
addMessage(_t("Up bandwidth limit is {0} KBps", _util.getMaxUpBW()));
addMessage(_t("Down bandwidth limit is {0} KBps", _bwManager.getUpBWLimit() / 1024) + "; " +
_t("Up bandwidth limit is {0} KBps", _util.getMaxUpBW()));
}
} else {
autostart = false;
......@@ -2623,10 +2737,13 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
if (ok)
cleanupTorrentStatus();
if (!routerOK) {
if (_context.isRouterContext())
if (_context.isRouterContext()) {
addMessage(_t("Unable to connect to I2P"));
else
addMessage(_t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort());
} else {
String msg = _t("Error connecting to I2P - check your I2CP settings!") + ' ' + _util.getI2CPHost() + ':' + _util.getI2CPPort();
addMessage(msg);
dtgNotify(Log.ERROR, msg);
}
}
}
try { Thread.sleep(60*1000); } catch (InterruptedException ie) {}
......@@ -2646,15 +2763,9 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
return;
if (snark.getDownloaded() > 0) {
addMessageNoEscape(_t("Download finished: {0}", linkify(snark)));
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null) {
NotificationService ns = (NotificationService) cmgr.getRegisteredApp("desktopgui");
if (ns != null) {
ns.notify("I2PSnark", null, Log.INFO, _t("I2PSnark"),
_t("Download finished: {0}", snark.getName()),
"/i2psnark/" + linkify(snark));
}
}
dtgNotify(Log.INFO,
_t("Download finished: {0}", snark.getBaseName()),
"/i2psnark/" + linkify(snark));
}
updateStatus(snark);
}
......@@ -2745,6 +2856,39 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
// End Snark.CompleteListeners
/**
* Send a notification to the user via desktopgui and,
* if standalone, on the console.
*
* @param priority log level
* @param message translated
* @since 0.9.54
*/
private void dtgNotify(int priority, String message) {
dtgNotify(priority, message, null);
}
/**
* Send a notification to the user via desktopgui and,
* if standalone, on the console.
*
* @param priority log level
* @param message translated
* @param path in console for more information, starting with /, must be URL-escaped, or null
* @since 0.9.54
*/
private void dtgNotify(int priority, String message, String path) {
ClientAppManager cmgr = _context.clientAppManager();
if (cmgr != null) {
NotificationService ns = (NotificationService) cmgr.getRegisteredApp("desktopgui");
if (ns != null)
ns.notify("I2PSnark", null, priority, _t("I2PSnark"), message, path);
cmgr.addBubble(PortMapper.SVC_I2PSNARK, message);
}
if (!_context.isRouterContext())
System.out.println(message);
}
/**
* An HTML link to the file if complete and a single file,
* to the directory if not complete or not a single file,
......@@ -2826,6 +2970,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
//if (_log.shouldLog(Log.DEBUG))
// _log.debug("DirMon found: " + DataHelper.toString(foundNames) + " existing: " + DataHelper.toString(existingNames));
// lets find new ones first...
int count = 0;
for (String name : foundNames) {
if (existingNames.contains(name)) {
// already known. noop
......@@ -2838,21 +2983,31 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
// don't let one bad torrent kill the whole loop
boolean ok = addTorrent(name, null, !shouldStart);
if (!ok) {
addMessage(_t("Error: Could not add the torrent {0}", name));
String msg = _t("Error: Could not add the torrent {0}", name);
addMessage(msg);
_log.error("Unable to add the torrent " + name);
disableTorrentFile(name);
dtgNotify(Log.ERROR, msg);
rv = false;
}
} catch (Snark.RouterException e) {
addMessage(_t("Error: Could not add the torrent {0}", name) + ": " + e);
String msg = _t("Error: Could not add the torrent {0}", name) + ": " + e;
addMessage(msg);
_log.error("Unable to add the torrent " + name, e);
dtgNotify(Log.ERROR, msg);
return false;
} catch (RuntimeException e) {
String msg = _t("Error: Could not add the torrent {0}", name) + ": " + e;
addMessage(_t("Error: Could not add the torrent {0}", name) + ": " + e);
_log.error("Unable to add the torrent " + name, e);
disableTorrentFile(name);
dtgNotify(Log.ERROR, msg);
rv = false;
}
if (shouldStart && (count++ & 0x0f) == 15) {
// try to prevent OOMs at startup
try { Thread.sleep(250); } catch (InterruptedException ie) {}
}
}
}
// Don't remove magnet torrents that don't have a torrent file yet
......@@ -3032,21 +3187,19 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
}
/**
* If not connected, thread it, otherwise inline
* Always thread it
* @since 0.9.1
*/
public void startAllTorrents() {
if (_util.connected()) {
startAll();
} else {
if (!_util.connected()) {
addMessage(_t("Opening the I2P tunnel and starting all torrents."));
for (Snark snark : _snarks.values()) {
// mark it for the UI
snark.setStarting();
}
(new I2PAppThread(new ThreadedStarter(null), "TorrentStarterAll", true)).start();
try { Thread.sleep(200); } catch (InterruptedException ie) {}
}
(new I2PAppThread(new ThreadedStarter(null), "TorrentStarterAll", true)).start();
try { Thread.sleep(200); } catch (InterruptedException ie) {}
}
/**
......@@ -3076,6 +3229,7 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
* @since 0.9.1
*/
private void startAll() {
int count = 0;
for (Snark snark : _snarks.values()) {
if (snark.isStopped()) {
try {
......@@ -3083,6 +3237,10 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
} catch (RuntimeException re) {
// Snark.fatal() will log and call fatal() here for user message before throwing
}
if ((count++ & 0x0f) == 15) {
// try to prevent OOMs
try { Thread.sleep(250); } catch (InterruptedException ie) {}
}
}
}
}
......@@ -3101,7 +3259,29 @@ public class SnarkManager implements CompleteListener, ClientApp, DisconnectList
if (finalShutdown && _log.shouldLog(Log.WARN))
_log.warn("SnarkManager final shutdown");
int count = 0;
for (Snark snark : _snarks.values()) {
Collection<Snark> snarks = _snarks.values();
// We do two passes so we shutdown the high-priority snarks first.
// Pass 1: All running, incomplete torrents,
// to make sure the status gets saved so there will be no recheck on restart.
for (Snark snark : snarks) {
if (!snark.isStopped()) {
Storage storage = snark.getStorage();
if (storage != null && !storage.complete()) {
if (count == 0)
addMessage(_t("Stopping all torrents and closing the I2P tunnel."));
count++;
if (finalShutdown)
snark.stopTorrent(true);
else
stopTorrent(snark, false);
if (count % 8 == 0) {
try { Thread.sleep(20); } catch (InterruptedException ie) {}
}
}
}
}
// Pass 2: All the rest of the torrents
for (Snark snark : snarks) {
if (!snark.isStopped()) {
if (count == 0)
addMessage(_t("Stopping all torrents and closing the I2P tunnel."));
......
......@@ -87,7 +87,7 @@ public class Storage implements Closeable
/** bigger than this will be rejected */
public static final int MAX_PIECE_SIZE = 32*1024*1024;
/** The maximum number of pieces in a torrent. */
public static final int MAX_PIECES = 32*1024;
public static final int MAX_PIECES = 64*1024;
public static final long MAX_TOTAL_SIZE = MAX_PIECE_SIZE * (long) MAX_PIECES;
public static final int PRIORITY_SKIP = -9;
public static final int PRIORITY_NORMAL = 0;
......@@ -288,9 +288,15 @@ public class Storage implements Closeable
* @throws IOException if too many total files
*/
private void addFiles(List<File> l, File f) throws IOException {
int max = _util.getMaxFilesPerTorrent();
if (!f.isDirectory()) {
if (l.size() >= SnarkManager.MAX_FILES_PER_TORRENT)
throw new IOException("Too many files, limit is " + SnarkManager.MAX_FILES_PER_TORRENT + ", zip them?");
int sz = l.size() + 1;
if (sz > max)
throw new IOException(_util.getString("Too many files in \"{0}\" ({1})!",
(metainfo != null ? metainfo.getName() : _base.toString()), sz) +
" - limit is " + max + ", zip them or set " +
SnarkManager.PROP_MAX_FILES_PER_TORRENT + '=' + sz + " in " +
SnarkManager.CONFIG_FILE + " and restart");
l.add(f);
} else {
File[] files = f.listFiles();
......@@ -301,6 +307,13 @@ public class Storage implements Closeable
+ "' not a normal file.");
return;
}
int sz = l.size() + files.length;
if (sz > max)
throw new IOException(_util.getString("Too many files in \"{0}\" ({1})!",
(metainfo != null ? metainfo.getName() : _base.toString()), sz) +
" - limit is " + max + ", zip them or set " +
SnarkManager.PROP_MAX_FILES_PER_TORRENT + '=' + sz + " in " +
SnarkManager.CONFIG_FILE + " and restart");
for (int i = 0; i < files.length; i++)
addFiles(l, files[i]);
}
......@@ -900,7 +913,10 @@ public class Storage implements Closeable
0x90, 0x91, 0x92, 0x93, 0x94, 0x95, 0x96, 0x97,
0x98, 0x99, 0x9a, 0x9b, 0x9c, 0x9d, 0x9e, 0x9f,
// unicode newlines
0x2028, 0x2029
0x2028, 0x2029,
// LTR/RTL
// https://security.stackexchange.com/questions/158802/how-can-this-executable-have-an-avi-extension
0x202a, 0x202b, 0x202c, 0x202d, 0x202e, 0x200e, 0x200f
};
// https://docs.microsoft.com/en-us/windows/desktop/FileIO/naming-a-file
......
......@@ -94,7 +94,8 @@ public class TrackerClient implements Runnable {
private static final Hash DSA_ONLY_TRACKER = ConvertToHash.getHash("cfmqlafjfmgkzbt4r3jsfyhgsr5abgxryl6fnz3d3y5a365di5aa.b32.i2p");
private final I2PSnarkUtil _util;
private final MetaInfo meta;
// non-final for reinitialize()
private MetaInfo meta;
private final String infoHash;
private final String peerID;
private final String additionalTrackerURL;
......@@ -266,8 +267,22 @@ public class TrackerClient implements Runnable {
}
}
/**
* Call after editing torrent
* @since 0.9.57
*/
public synchronized void reinitialize() {
if (!_initialized || !stop)
return;
trackers.clear();
backupTrackers.clear();
meta = snark.getMetaInfo();
setup();
}
/**
* Do this one time only (not every time it is started).
* Unless torrent was edited.
* @since 0.9.1
*/
private void setup() {
......
package org.klomp.snark;
import java.util.Collections;
import java.util.HashSet;
import java.util.Map;
import java.util.Set;
import java.util.concurrent.ConcurrentHashMap;
import net.i2p.I2PAppContext;
import net.i2p.client.I2PSession;
import net.i2p.client.I2PSessionException;
import net.i2p.client.I2PSessionMuxedListener;
import net.i2p.client.SendMessageOptions;
import net.i2p.client.datagram.I2PDatagramDissector;
import net.i2p.client.datagram.I2PDatagramMaker;
import net.i2p.client.datagram.I2PInvalidDatagramException;
import net.i2p.data.DataFormatException;
import net.i2p.data.DataHelper;
import net.i2p.data.Destination;
import net.i2p.data.Hash;
import net.i2p.util.Log;
import net.i2p.util.SimpleTimer2;
/**
* One of these for all trackers and info hashes.
* Ref: BEP 15, proposal 160
*
* The main difference from BEP 15 is that the announce response
* contains a 32-byte hash instead of a 4-byte IP and a 2-byte port.
*
* This implements only "fast mode".
* We send only repliable datagrams, and
* receive only raw datagrams, as follows:
*
*<pre>
* client tracker type
* ------ ------- ----
* announce --&gt; repliable
* &lt;-- ann resp raw
*</pre>
*
* @since 0.9.53, enabled in 0.9.54
*/
class UDPTrackerClient implements I2PSessionMuxedListener {
private final I2PAppContext _context;
private final Log _log;
/** hook to inject and receive datagrams */
private final I2PSession _session;
private final I2PSnarkUtil _util;
private final Hash _myHash;
/** unsigned dgrams */
private final int _rPort;
/** dest and port to tracker data */
private final ConcurrentHashMap<HostPort, Tracker> _trackers;
/** our TID to tracker */
private final Map<Integer, ReplyWaiter> _sentQueries;
private boolean _isRunning;
public static final int EVENT_NONE = 0;
public static final int EVENT_COMPLETED = 1;
public static final int EVENT_STARTED = 2;
public static final int EVENT_STOPPED = 3;
private static final int ACTION_CONNECT = 0;
private static final int ACTION_ANNOUNCE = 1;
private static final int ACTION_SCRAPE = 2;
private static final int ACTION_ERROR = 3;
private static final int SEND_CRYPTO_TAGS = 8;
private static final int LOW_CRYPTO_TAGS = 4;
private static final long DEFAULT_TIMEOUT = 15*1000;
private static final long DEFAULT_QUERY_TIMEOUT = 60*1000;
private static final long CLEAN_TIME = 163*1000;
/** in seconds */
private static final int DEFAULT_INTERVAL = 60*60;
private static final int MIN_INTERVAL = 15*60;
private static final int MAX_INTERVAL = 8*60*60;
private enum WaitState { INIT, SUCCESS, TIMEOUT, FAIL }
/**
*
*/
public UDPTrackerClient(I2PAppContext ctx, I2PSession session, I2PSnarkUtil util) {
_context = ctx;
_session = session;
_util = util;
_log = ctx.logManager().getLog(UDPTrackerClient.class);
_rPort = TrackerClient.PORT - 1;
_myHash = session.getMyDestination().calculateHash();
_trackers = new ConcurrentHashMap<HostPort, Tracker>(8);
_sentQueries = new ConcurrentHashMap<Integer, ReplyWaiter>(32);
}
/**
* Can't be restarted after stopping?
*/
public synchronized void start() {
if (_isRunning)
return;
_session.addMuxedSessionListener(this, I2PSession.PROTO_DATAGRAM_RAW, _rPort);
_isRunning = true;
}
/**
* Stop everything.
*/
public synchronized void stop() {
if (!_isRunning)
return;
_isRunning = false;
_session.removeListener(I2PSession.PROTO_DATAGRAM_RAW, _rPort);
_trackers.clear();
for (ReplyWaiter w : _sentQueries.values()) {
w.cancel();
}
_sentQueries.clear();
}
/**
* Announce and get peers for a torrent.
* Blocking!
* Caller should run in a thread.
*
* @param ih the Info Hash (torrent)
* @param max maximum number of peers to return
* @param maxWait the maximum time to wait (ms) must be greater than 0
* @param fast if true, don't wait for dest, no retx, ...
* @return null on fail or if fast is true
*/
public TrackerResponse announce(byte[] ih, byte[] peerID, int max, long maxWait,
String toHost, int toPort,
long downloaded, long left, long uploaded,
int event, boolean fast) {
long now = _context.clock().now();
long end = now + maxWait;
if (toPort < 0)
throw new IllegalArgumentException();
Tracker tr = getTracker(toHost, toPort);
if (tr.getDest(fast) == null) {
if (_log.shouldInfo())
_log.info("cannot resolve " + tr);
return null;
}
long toWait = end - now;
if (!fast)
toWait = toWait * 3 / 4;
if (toWait < 1000) {
if (_log.shouldInfo())
_log.info("out of time after resolving: " + tr);
return null;
}
if (fast) {
toWait = 0;
} else {
toWait = end - now;
if (toWait < 1000) {
if (_log.shouldInfo())
_log.info("out of time after getting conn: " + tr);
return null;
}
}
ReplyWaiter w = sendAnnounce(tr, 0, ih, peerID,
downloaded, left, uploaded, event, max, toWait);
if (fast)
return null;
if (w == null) {
if (_log.shouldInfo())
_log.info("initial announce failed: " + tr);
return null;
}
boolean success = waitAndRetransmit(w, end);
_sentQueries.remove(w.getID());
if (success)
return w.getReplyObject();
if (_log.shouldInfo())
_log.info("announce failed after retx: " + tr);
return null;
}
//////// private below here
/**
* @return non-null
*/
private Tracker getTracker(String host, int port) {
Tracker ndp = new Tracker(host, port);
Tracker odp = _trackers.putIfAbsent(ndp, ndp);
if (odp != null)
ndp = odp;
return ndp;
}
///// Sending.....
/**
* Send one time with a new tid
* @param toWait if <= 0 does not register
* @return null on failure or if toWait <= 0
*/
private ReplyWaiter sendAnnounce(Tracker tr, long connID,
byte[] ih, byte[] id,
long downloaded, long left, long uploaded,
int event, int numWant, long toWait) {
int tid = _context.random().nextInt();
byte[] payload = sendAnnounce(tr, tid, connID, ih, id, downloaded, left, uploaded, event, numWant);
if (payload != null) {
if (toWait > 0) {
ReplyWaiter rv = new ReplyWaiter(tid, tr, payload, toWait);
_sentQueries.put(Integer.valueOf(tid), rv);
if (_log.shouldInfo())
_log.info("Sent: " + rv + " timeout: " + toWait);
return rv;
}
if (_log.shouldInfo())
_log.info("Sent annc " + event + " to " + tr + " no wait");
}
return null;
}
/**
* Send one time with given tid
* @return the payload or null on failure
*/
private byte[] sendAnnounce(Tracker tr, int tid, long connID,
byte[] ih, byte[] id,
long downloaded, long left, long uploaded,
int event, int numWant) {
byte[] payload = new byte[98];
DataHelper.toLong8(payload, 0, connID);
DataHelper.toLong(payload, 8, 4, ACTION_ANNOUNCE);
DataHelper.toLong(payload, 12, 4, tid);
System.arraycopy(ih, 0, payload, 16, 20);
System.arraycopy(id, 0, payload, 36, 20);
DataHelper.toLong(payload, 56, 8, downloaded);
DataHelper.toLong(payload, 64, 8, left);
DataHelper.toLong(payload, 72, 8, uploaded);
DataHelper.toLong(payload, 80, 4, event);
DataHelper.toLong(payload, 92, 4, numWant);
DataHelper.toLong(payload, 96, 2, TrackerClient.PORT);
boolean rv = sendMessage(tr.getDest(true), tr.getPort(), payload, true);
return rv ? payload : null;
}
/**
* wait after initial send, resend if necessary
*/
private boolean waitAndRetransmit(ReplyWaiter w, long untilTime) {
synchronized(w) {
while(true) {
try {
long toWait = untilTime - _context.clock().now();
if (toWait <= 0)
return false;
w.wait(toWait);
} catch (InterruptedException ie) {
return false;
}
switch (w.getState()) {
case INIT:
continue;
case SUCCESS:
return true;
case FAIL:
return false;
case TIMEOUT:
if (_log.shouldInfo())
_log.info("Timeout: " + w);
long toWait = untilTime - _context.clock().now();
if (toWait <= 1000)
return false;
boolean ok = resend(w, Math.min(toWait, w.getSentTo().getTimeout()));
if (!ok)
return false;
continue;
}
}
}
}
/**
* Resend the stored payload
* @return success
*/
private boolean resend(ReplyWaiter w, long toWait) {
Tracker tr = w.getSentTo();
int port = tr.getPort();
if (_log.shouldInfo())
_log.info("Resending: " + w + " timeout: " + toWait);
boolean rv = sendMessage(tr.getDest(true), port, w.getPayload(), true);
if (rv) {
_sentQueries.put(Integer.valueOf(w.getID()), w);
w.schedule(toWait);
}
return rv;
}
/**
* Lowest-level send message call.
* @param dest may be null, returns false
* @param repliable true for conn request, false for announce
* @return success
*/
private boolean sendMessage(Destination dest, int toPort, byte[] payload, boolean repliable) {
if (!_isRunning) {
if (_log.shouldInfo())
_log.info("send failed, not running");
return false;
}
if (dest == null) {
if (_log.shouldInfo())
_log.info("send failed, no dest");
return false;
}
if (dest.calculateHash().equals(_myHash))
throw new IllegalArgumentException("don't send to ourselves");
if (repliable) {
I2PDatagramMaker dgMaker = new I2PDatagramMaker(_session);
payload = dgMaker.makeI2PDatagram(payload);
if (payload == null) {
if (_log.shouldWarn())
_log.warn("DGM fail");
return false;
}
}
SendMessageOptions opts = new SendMessageOptions();
opts.setDate(_context.clock().now() + 60*1000);
opts.setTagsToSend(SEND_CRYPTO_TAGS);
opts.setTagThreshold(LOW_CRYPTO_TAGS);
if (!repliable)
opts.setSendLeaseSet(false);
try {
boolean success = _session.sendMessage(dest, payload, 0, payload.length,
repliable ? I2PSession.PROTO_DATAGRAM : I2PSession.PROTO_DATAGRAM_RAW,
_rPort, toPort, opts);
if (success) {
// ...
} else {
if (_log.shouldWarn())
_log.warn("sendMessage fail");
}
return success;
} catch (I2PSessionException ise) {
if (_log.shouldWarn())
_log.warn("sendMessage fail", ise);
return false;
}
}
///// Reception.....
/**
* @param from dest or null if it didn't come in on signed port
*/
private void receiveMessage(Destination from, int fromPort, byte[] payload) {
if (payload.length < 8) {
if (_log.shouldInfo())
_log.info("Got short message: " + payload.length + " bytes");
return;
}
int action = (int) DataHelper.fromLong(payload, 0, 4);
int tid = (int) DataHelper.fromLong(payload, 4, 4);
ReplyWaiter waiter = _sentQueries.remove(Integer.valueOf(tid));
if (waiter == null) {
if (_log.shouldInfo())
_log.info("Rcvd msg with no one waiting: " + tid);
return;
}
if (action == ACTION_ANNOUNCE) {
receiveAnnounce(waiter, payload);
} else if (action == ACTION_ERROR) {
receiveError(waiter, payload);
} else {
// includes ACTION_CONNECT
if (_log.shouldInfo())
_log.info("Rcvd msg with unknown action: " + action + " for: " + waiter);
waiter.gotReply(false);
Tracker tr = waiter.getSentTo();
tr.gotError();
}
}
private void receiveAnnounce(ReplyWaiter waiter, byte[] payload) {
Tracker tr = waiter.getSentTo();
if (payload.length >= 22) {
int interval = Math.min(MAX_INTERVAL, Math.max(MIN_INTERVAL,
(int) DataHelper.fromLong(payload, 8, 4)));
int leeches = (int) DataHelper.fromLong(payload, 12, 4);
int seeds = (int) DataHelper.fromLong(payload, 16, 4);
int peers = (int) DataHelper.fromLong(payload, 20, 2);
if (22 + (peers * Hash.HASH_LENGTH) > payload.length) {
if (_log.shouldWarn())
_log.warn("Short reply");
waiter.gotReply(false);
tr.gotError();
return;
}
if (_log.shouldInfo())
_log.info("Rcvd " + peers + " peers from " + tr);
Set<Hash> hashes;
if (peers > 0) {
hashes = new HashSet<Hash>(peers);
for (int off = 20; off < payload.length; off += Hash.HASH_LENGTH) {
hashes.add(Hash.create(payload, off));
}
} else {
hashes = Collections.emptySet();
}
TrackerResponse resp = new TrackerResponse(interval, seeds, leeches, hashes);
waiter.gotResponse(resp);
tr.setInterval(interval);
} else {
waiter.gotReply(false);
tr.gotError();
}
}
private void receiveError(ReplyWaiter waiter, byte[] payload) {
String msg;
if (payload.length > 8) {
msg = DataHelper.getUTF8(payload, 8, payload.length - 8);
} else {
msg = "";
}
TrackerResponse resp = new TrackerResponse(msg);
waiter.gotResponse(resp);
Tracker tr = waiter.getSentTo();
tr.gotError();
}
// I2PSessionMuxedListener interface ----------------
/**
* Instruct the client that the given session has received a message
*
* Will be called only if you register via addMuxedSessionListener().
* Will be called only for the proto(s) and toPort(s) you register for.
*
* @param session session to notify
* @param msgId message number available
* @param size size of the message - why it's a long and not an int is a mystery
* @param proto 1-254 or 0 for unspecified
* @param fromPort 1-65535 or 0 for unspecified
* @param toPort 1-65535 or 0 for unspecified
*/
public void messageAvailable(I2PSession session, int msgId, long size, int proto, int fromPort, int toPort) {
// TODO throttle
try {
byte[] payload = session.receiveMessage(msgId);
if (payload == null)
return;
if (toPort == _rPort) {
// raw
receiveMessage(null, fromPort, payload);
} else {
if (_log.shouldWarn())
_log.warn("msg on bad port");
}
} catch (I2PSessionException e) {
if (_log.shouldWarn())
_log.warn("bad msg");
}
}
/** for non-muxed */
public void messageAvailable(I2PSession session, int msgId, long size) {}
public void reportAbuse(I2PSession session, int severity) {}
public void disconnected(I2PSession session) {
if (_log.shouldWarn())
_log.warn("UDPTC disconnected");
}
public void errorOccurred(I2PSession session, String message, Throwable error) {
if (_log.shouldWarn())
_log.warn("UDPTC got error msg: ", error);
}
public static class TrackerResponse {
private final int interval, complete, incomplete;
private final String error;
private final Set<Hash> peers;
/** success */
public TrackerResponse(int interval, int seeds, int leeches, Set<Hash> peers) {
this.interval = interval;
complete = seeds;
incomplete = leeches;
this.peers = peers;
error = null;
}
/** failure */
public TrackerResponse(String errorMsg) {
interval = DEFAULT_INTERVAL;
complete = 0;
incomplete = 0;
peers = null;
error = errorMsg;
}
public Set<Hash> getPeers() {
return peers;
}
public int getPeerCount() {
int pc = peers == null ? 0 : peers.size();
return Math.max(pc, complete + incomplete - 1);
}
public int getSeedCount() {
return complete;
}
public int getLeechCount() {
return incomplete;
}
public String getFailureReason() {
return error;
}
/** in seconds */
public int getInterval() {
return interval;
}
}
private static class HostPort {
protected final String host;
protected final int port;
/**
* @param port the announce port
*/
public HostPort(String host, int port) {
this.host = host;
this.port = port;
}
/**
* @return the announce port
*/
public int getPort() {
return port;
}
@Override
public int hashCode() {
return host.hashCode() ^ port;
}
@Override
public boolean equals(Object o) {
if (o == null || !(o instanceof HostPort))
return false;
HostPort dp = (HostPort) o;
return port == dp.port && host.equals(dp.host);
}
@Override
public String toString() {
return "UDP Tracker " + host + ':' + port;
}
}
private class Tracker extends HostPort {
private final Object destLock = new Object();
private Destination dest;
private long expires;
private long lastHeardFrom;
private long lastFailed;
private int consecFails;
private int interval = DEFAULT_INTERVAL;
private static final long DELAY = 15*1000;
public Tracker(String host, int port) {
super(host, port);
}
/**
* @param fast if true, do not lookup
* @return dest or null
*/
public Destination getDest(boolean fast) {
synchronized(destLock) {
if (dest == null && !fast)
dest = _util.getDestination(host);
return dest;
}
}
/** does not change state */
public synchronized void replyTimeout() {
consecFails++;
lastFailed = _context.clock().now();
}
public synchronized int getInterval() {
return interval;
}
/** sets heardFrom; calls notify */
public synchronized void setInterval(int interval) {
long now = _context.clock().now();
lastHeardFrom = now;
consecFails = 0;
this.interval = interval;
this.notifyAll();
}
/** sets heardFrom; calls notify */
public synchronized void gotError() {
long now = _context.clock().now();
lastHeardFrom = now;
consecFails = 0;
this.notifyAll();
}
/** doubled for each consecutive failure */
public synchronized long getTimeout() {
return DEFAULT_TIMEOUT << Math.min(consecFails, 3);
}
@Override
public String toString() {
return "UDP Tracker " + host + ':' + port + " hasDest? " + (dest != null);
}
}
/**
* Callback for replies
*/
private class ReplyWaiter extends SimpleTimer2.TimedEvent {
private final int tid;
private final Tracker sentTo;
private final byte[] data;
private TrackerResponse replyObject;
private WaitState state = WaitState.INIT;
/**
* Either wait on this object with a timeout, or use non-null Runnables.
* Any sent data to be remembered may be stored by setSentObject().
* Reply object may be in getReplyObject().
*/
public ReplyWaiter(int tid, Tracker tracker, byte[] payload, long toWait) {
super(SimpleTimer2.getInstance(), toWait);
this.tid = tid;
sentTo = tracker;
data = payload;
}
public int getID() {
return tid;
}
public Tracker getSentTo() {
return sentTo;
}
public byte[] getPayload() {
return data;
}
/**
* @return may be null depending on what happened. Cast to expected type.
*/
public synchronized TrackerResponse getReplyObject() {
return replyObject;
}
/**
* If true, we got a reply, and getReplyObject() may contain something.
*/
public synchronized WaitState getState() {
return state;
}
/**
* Will notify this.
* Also removes from _sentQueries and calls heardFrom().
* Sets state to SUCCESS or FAIL.
*/
public synchronized void gotReply(boolean success) {
cancel();
_sentQueries.remove(Integer.valueOf(tid));
setState(success ? WaitState.SUCCESS : WaitState.FAIL);
}
/**
* Will notify this and run onReply.
* Also removes from _sentQueries and calls heardFrom().
*/
private synchronized void setState(WaitState state) {
this.state = state;
this.notifyAll();
}
/**
* Will notify this.
* Also removes from _sentQueries and calls heardFrom().
* Sets state to SUCCESS.
*/
public synchronized void gotResponse(TrackerResponse resp) {
replyObject = resp;
gotReply(true);
}
/**
* Sets state to INIT.
*/
@Override
public synchronized void schedule(long toWait) {
state = WaitState.INIT;
super.schedule(toWait);
}
/** timer callback on timeout */
public synchronized void timeReached() {
// don't trump success or failure
if (state != WaitState.INIT)
return;
//if (action == ACTION_CONNECT)
// sentTo.connFailed();
//else
sentTo.replyTimeout();
setState(WaitState.TIMEOUT);
if (_log.shouldWarn())
_log.warn("timeout waiting for reply from " + sentTo);
}
@Override
public String toString() {
return "Waiting for ID: " + tid + " to: " + sentTo + " state: " + state;
}
}
}
......@@ -319,6 +319,13 @@ class UpdateRunner implements UpdateTask, CompleteListener {
return _smgr.shouldAutoStart();
}
/**
* @since 0.9.62
*/
public BandwidthListener getBandwidthListener() {
return _smgr.getBandwidthListener();
}
//////// end CompleteListener methods
private static String linkify(String url) {
......
......@@ -122,7 +122,7 @@ class WebPeer extends Peer implements EepGet.StatusListener {
* @param uploadOnly if we are complete with skipped files, i.e. a partial seed
*/
@Override
public void runConnection(I2PSnarkUtil util, PeerListener listener, BitField ignore,
public void runConnection(I2PSnarkUtil util, PeerListener listener, BandwidthListener bwl, BitField ignore,
MagnetState mState, boolean uploadOnly) {
if (uploadOnly)
return;
......@@ -204,6 +204,8 @@ class WebPeer extends Peer implements EepGet.StatusListener {
if (i >= maxRequests)
break;
Request r = outstandingRequests.get(i);
if (!shouldRequest(r.len))
break;
if (r.getPiece() == piece &&
lastRequest.off + lastRequest.len == r.off) {
requests.add(r);
......@@ -340,7 +342,7 @@ class WebPeer extends Peer implements EepGet.StatusListener {
Request req = iter.next();
if (dis.available() < req.len)
break;
req.read(dis);
req.read(dis, this);
iter.remove();
if (_log.shouldWarn())
_log.warn("Saved chunk " + req + " recvd before failure");
......@@ -363,13 +365,13 @@ class WebPeer extends Peer implements EepGet.StatusListener {
_log.debug("Fetch of piece: " + piece + " chunks: " + requests.size() + " offset: " + off + " torrent offset: " + toff + " len: " + tlen + " successful");
DataInputStream dis = new DataInputStream(new ByteArrayInputStream(out.toByteArray()));
for (Request req : requests) {
req.read(dis);
req.read(dis, this);
}
PartialPiece pp = last.getPartialPiece();
synchronized(pp) {
// Last chunk needed for this piece?
if (pp.getLength() == pp.getDownloaded()) {
if (pp.isComplete()) {
if (listener.gotPiece(this, pp)) {
if (_log.shouldDebug())
_log.debug("Got " + piece + ": " + this);
......@@ -519,6 +521,29 @@ class WebPeer extends Peer implements EepGet.StatusListener {
return false;
}
// begin BandwidthListener interface overrides
// Because super doesn't have a PeerState
/**
* @since 0.9.62
*/
@Override
public void downloaded(int size) {
super.downloaded(size);
_coordinator.downloaded(size);
}
/**
* Should we request this many bytes?
* @since 0.9.62
*/
@Override
public boolean shouldRequest(int size) {
return _coordinator.shouldRequest(this, size);
}
// end BandwidthListener interface overrides
// private methods below here implementing parts of PeerState
private synchronized void addRequest() {
......@@ -548,7 +573,8 @@ class WebPeer extends Peer implements EepGet.StatusListener {
Request req = new Request(nextPiece,nextBegin, nextLength);
outstandingRequests.add(req);
lastRequest = req;
this.notifyAll();
if (shouldRequest(maxLength))
this.notifyAll();
}
}
}
......@@ -567,7 +593,8 @@ class WebPeer extends Peer implements EepGet.StatusListener {
Request r = pp.getRequest();
outstandingRequests.add(r);
lastRequest = r;
this.notifyAll();
if (shouldRequest(r.len))
this.notifyAll();
return true;
} else {
if (_log.shouldLog(Log.WARN))
......@@ -623,15 +650,8 @@ class WebPeer extends Peer implements EepGet.StatusListener {
List<Request> rv = new ArrayList<Request>(pcs.size());
for (Integer p : pcs) {
Request req = getLowestOutstandingRequest(p.intValue());
if (req != null) {
PartialPiece pp = req.getPartialPiece();
synchronized(pp) {
int dl = pp.getDownloaded();
if (req.off != dl)
req = new Request(pp, dl);
}
if (req != null)
rv.add(req);
}
}
outstandingRequests.clear();
return rv;
......@@ -653,8 +673,6 @@ class WebPeer extends Peer implements EepGet.StatusListener {
public void bytesTransferred(long alreadyTransferred, int currentWrite, long bytesTransferred, long bytesRemaining, String url) {
lastRcvd = System.currentTimeMillis();
downloaded(currentWrite);
listener.downloaded(this, currentWrite);
}
public void attemptFailed(String url, long bytesTransferred, long bytesRemaining, int currentAttempt, int numRetries, Exception cause) {}
......
......@@ -294,7 +294,7 @@ public class BDecoder
/**
* Returns the next bencoded value on the stream and makes sure it
* is a map (dictonary). If it is not a map it will throw
* is a map (dictionary). If it is not a map it will throw
* InvalidBEncodingException.
*/
public BEValue bdecodeMap() throws IOException
......@@ -311,7 +311,7 @@ public class BDecoder
c = getNextIndicator();
while (c != 'e')
{
// Dictonary keys are always strings.
// Dictionary keys are always strings.
String key = bdecode().getString();
// XXX ugly hack
......
......@@ -32,7 +32,7 @@ public class Comment implements Comparable<Comment> {
public static final int MAX_NAME_LEN = 32;
// same as IRC, more or less
private static final int MAX_TEXT_LEN = 512;
private static final int BUCKET_SIZE = 10*60*1000;
private static final int BUCKET_SIZE = 4*60*60*1000;
private static final long TIME_SHRINK = 1000L;
private static final int MAX_SKEW = (int) (BUCKET_SIZE / TIME_SHRINK);
// 1/1/2005
......
......@@ -100,6 +100,7 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
private final ConcurrentHashMap<NID, Token> _incomingTokens;
/** recently unreachable, with lastSeen() as the added-to-blacklist time */
private final Set<NID> _blacklist;
private SimpleTimer2.TimedEvent _cleaner, _explorer;
/** hook to inject and receive datagrams */
private final I2PSession _session;
......@@ -623,6 +624,8 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
public synchronized void start() {
if (_isRunning)
return;
if (_log.shouldInfo())
_log.info("KRPC start", new Exception());
_session.addMuxedSessionListener(this, I2PSession.PROTO_DATAGRAM_RAW, _rPort);
_session.addMuxedSessionListener(this, I2PSession.PROTO_DATAGRAM, _qPort);
_knownNodes.start();
......@@ -630,9 +633,8 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
PersistDHT.loadDHT(this, _dhtFile, _backupDhtFile);
// start the explore thread
_isRunning = true;
// no need to keep ref, it will eventually stop
new Cleaner();
new Explorer(5*1000);
_cleaner = new Cleaner();
_explorer = new Explorer(5*1000);
_txPkts.set(0);
_rxPkts.set(0);
_txBytes.set(0);
......@@ -648,7 +650,10 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
if (!_isRunning)
return;
_isRunning = false;
// FIXME stop the explore thread
if (_log.shouldInfo())
_log.info("KRPC stop", new Exception());
_cleaner.cancel();
_explorer.cancel();
// unregister port listeners
_session.removeListener(I2PSession.PROTO_DATAGRAM, _qPort);
_session.removeListener(I2PSession.PROTO_DATAGRAM_RAW, _rPort);
......@@ -683,7 +688,7 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
public String renderStatusHTML() {
long uptime = Math.max(1000, _context.clock().now() - _started);
StringBuilder buf = new StringBuilder(256);
buf.append("<br><hr class=\"debug\"><b>DHT DEBUG</b><br><hr class=\"debug\"><hr><b>TX:</b> ").append(_txPkts.get()).append(" pkts / ")
buf.append("<br><hr class=\"debug\"><br><hr class=\"debug\"><hr><b>TX:</b> ").append(_txPkts.get()).append(" pkts / ")
.append(DataHelper.formatSize2(_txBytes.get())).append("B / ")
.append(DataHelper.formatSize2Decimal(_txBytes.get() * 1000 / uptime)).append("Bps<br>" +
"<b>RX:</b> ").append(_rxPkts.get()).append(" pkts / ")
......@@ -1640,6 +1645,7 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
public void disconnected(I2PSession session) {
if (_log.shouldLog(Log.WARN))
_log.warn("KRPC disconnected");
stop();
}
public void errorOccurred(I2PSession session, String message, Throwable error) {
......@@ -1760,7 +1766,7 @@ public class KRPC implements I2PSessionMuxedListener, DHT {
}
if (_log.shouldLog(Log.INFO))
_log.info("Explore of " + keys.size() + " buckets done, new size: " + _knownNodes.size());
new Explorer(EXPLORE_TIME);
_explorer = new Explorer(EXPLORE_TIME);
}
}
}
......@@ -31,12 +31,14 @@ public class ConfigUIHelper {
{ "az", "az", "Azerbaijani", null },
{ "cs", "cz", "Čeština", null },
{ "zh", "cn", "Chinese 中文", null },
//{ "zh_TW", "tw", "Chinese 中文", "Taiwan" },
{ "zh_TW", "tw", "Chinese 中文", "Taiwan" },
{ "gan", "cn", "Gan Chinese 赣语", null },
{ "da", "dk", "Dansk", null },
{ "de", "de", "Deutsch", null },
//{ "et", "ee", "Eesti", null },
{ "en", "us", "English", null },
{ "es", "es", "Español", null },
{ "es_AR", "ar", "Español" ,"Argentina" },
{ "fa", "ir", "Persian فارسی", null },
{ "fr", "fr", "Français", null },
//{ "gl", "lang_gl", "Galego", null },
......
package org.klomp.snark.standalone;
import java.awt.GraphicsEnvironment;
import java.io.File;
import java.io.IOException;
import java.util.Properties;
......@@ -7,10 +8,18 @@ import java.util.Properties;
import org.eclipse.jetty.util.log.Log;
import net.i2p.I2PAppContext;
import net.i2p.app.MenuCallback;
import net.i2p.app.MenuHandle;
import net.i2p.app.MenuService;
import net.i2p.apps.systray.UrlLauncher;
import net.i2p.data.DataHelper;
import net.i2p.desktopgui.ExternalMain;
import net.i2p.jetty.I2PLogger;
import net.i2p.jetty.JettyStart;
import net.i2p.util.I2PAppThread;
import net.i2p.util.SystemVersion;
import org.klomp.snark.SnarkManager;
/**
* @since moved from ../web and fixed in 0.9.27
......@@ -23,6 +32,7 @@ public class RunStandalone {
private String _host = "127.0.0.1";
private static RunStandalone _instance;
static final File APP_CONFIG_FILE = new File("i2psnark-appctx.config");
private static final String PROP_DTG_ENABLED = "desktopgui.enabled";
private RunStandalone(String args[]) throws Exception {
Properties p = new Properties();
......@@ -66,13 +76,20 @@ public class RunStandalone {
public void start() {
try {
_jettyStart.startup();
String url = "http://" + _host + ':' + _port + "/i2psnark/";
System.out.println("Starting i2psnark " + SnarkManager.FULL_VERSION + " at " + url);
MenuService dtg = startTrayApp();
_jettyStart.startup();
try {
Thread.sleep(1000);
} catch (InterruptedException ie) {}
UrlLauncher launch = new UrlLauncher(_context, null, new String[] { url } );
launch.startup();
String p = _context.getProperty("routerconsole.browser");
if (!("/bin/false".equals(p) || "NUL".equals(p))) {
UrlLauncher launch = new UrlLauncher(_context, null, new String[] { url } );
launch.startup();
}
if (dtg != null)
dtg.addMenu("Shutdown I2PSnark", new StandaloneStopper(dtg));
} catch (Exception e) {
e.printStackTrace();
}
......@@ -92,4 +109,70 @@ public class RunStandalone {
} catch (InterruptedException ie) {}
System.exit(1);
}
/**
* @since 0.9.54 adapted from RouterConsoleRunner
*/
private static boolean isSystrayEnabled(I2PAppContext context) {
if (GraphicsEnvironment.isHeadless())
return false;
// default false except on OSX and Windows,
// and on Linux KDE and LXDE.
// Xubuntu XFCE works but doesn't look very good
// Ubuntu Unity was far too buggy to enable
// Ubuntu GNOME does not work, SystemTray.isSupported() returns false
String xdg = System.getenv("XDG_CURRENT_DESKTOP");
boolean dflt = SystemVersion.isWindows() ||
SystemVersion.isMac() ||
//"XFCE".equals(xdg) ||
"KDE".equals(xdg) ||
"LXDE".equals(xdg);
return context.getProperty(PROP_DTG_ENABLED, dflt);
}
/**
* @since 0.9.54 adapted from RouterConsoleRunner
* @return null on failure
*/
private MenuService startTrayApp() {
try {
if (isSystrayEnabled(_context)) {
System.setProperty("java.awt.headless", "false");
ExternalMain dtg = new ExternalMain(_context, _context.clientAppManager(), null);
dtg.startup();
return dtg;
}
} catch (Throwable t) {
t.printStackTrace();
}
return null;
}
/**
* Callback when shutdown is clicked in systray
* @since 0.9.61
*/
public static class StandaloneStopper implements MenuCallback {
private final MenuService _ms;
public StandaloneStopper(MenuService ms) { _ms = ms; }
public void clicked(MenuHandle menu) {
_ms.disableMenu(menu);
_ms.updateMenu("I2PSnark shutting down", menu);
Thread t = new I2PAppThread(new StopperThread(), "Snark Stopper", true);
t.start();
}
}
/**
* Threaded shutdown
* @since 0.9.61
*/
public static class StopperThread implements Runnable {
public void run() {
shutdown();
}
}
}
......@@ -395,11 +395,11 @@ class BasicServlet extends HttpServlet
String rtype = response.getContentType();
String ctype = content.getContentType();
if (rtype != null) {
if (rtype.equals("application/javascript"))
if (rtype.contains("javascript"))
response.setCharacterEncoding("ISO-8859-1");
} else if (ctype != null) {
response.setContentType(ctype);
if (ctype.equals("application/javascript"))
if (ctype.contains("javascript"))
response.setCharacterEncoding("ISO-8859-1");
}
response.setHeader("X-Content-Type-Options", "nosniff");
......@@ -586,6 +586,17 @@ class BasicServlet extends HttpServlet
protected static String addPaths(String base, String path) {
if (path == null)
return base;
if (path.equals("/")) {
// Java 17 and below:
// (new File("foo", "/")).toString() = "foo/"
// (new File("foo/", "/")).toString() = "foo/"
// Java 21:
// (new File("foo", "/")).toString() = "foo"
// (new File("foo/", "/")).toString() = "foo"
if (base.endsWith("/"))
return base;
return base + path;
}
String rv = (new File(base, path)).toString();
if (SystemVersion.isWindows())
rv = rv.replace("\\", "/");
......
......@@ -3,6 +3,7 @@ package org.klomp.snark.web;
import java.io.File;
import java.io.FileInputStream;
import java.io.IOException;
import java.io.InputStream;
import java.io.OutputStream;
import java.io.PrintWriter;
import java.io.Serializable;
......@@ -12,6 +13,7 @@ import java.net.URI;
import java.net.URISyntaxException;
import java.text.Collator;
import java.text.DecimalFormat;
import java.text.Normalizer;
import java.util.ArrayList;
import java.util.Arrays;
import java.util.Collection;
......@@ -37,6 +39,7 @@ import net.i2p.data.Base32;
import net.i2p.data.Base64;
import net.i2p.data.DataHelper;
import net.i2p.data.Hash;
import net.i2p.servlet.RequestWrapper;
import net.i2p.servlet.util.ServletUtil;
import net.i2p.util.FileUtil;
import net.i2p.util.Log;
......@@ -46,6 +49,7 @@ import net.i2p.util.SystemVersion;
import net.i2p.util.Translate;
import net.i2p.util.UIMessages;
import org.klomp.snark.BandwidthListener;
import org.klomp.snark.I2PSnarkUtil;
import org.klomp.snark.MagnetURI;
import org.klomp.snark.MetaInfo;
......@@ -57,6 +61,8 @@ import org.klomp.snark.Storage;
import org.klomp.snark.Tracker;
import org.klomp.snark.TrackerClient;
import org.klomp.snark.URIUtil;
import org.klomp.snark.bencode.BEValue;
import org.klomp.snark.bencode.InvalidBEncodingException;
import org.klomp.snark.dht.DHT;
import org.klomp.snark.comments.Comment;
import org.klomp.snark.comments.CommentSet;
......@@ -212,7 +218,7 @@ public class I2PSnarkServlet extends BasicServlet {
req.setCharacterEncoding("UTF-8");
String pOverride = _manager.util().connected() ? null : "";
String peerString = getQueryString(req, pOverride, null, null);
String peerString = getQueryString(req, pOverride, null, null, "");
String cspNonce = Integer.toHexString(_context.random().nextInt());
// AJAX for mainsection
......@@ -285,7 +291,9 @@ public class I2PSnarkServlet extends BasicServlet {
String nonce = req.getParameter("nonce");
if (nonce != null) {
if (nonce.equals(String.valueOf(_nonce)))
// the clear messages button is a GET
if ((method.equals("POST") || "Clear".equals(req.getParameter("action"))) &&
nonce.equals(String.valueOf(_nonce)))
processRequest(req);
else // nonce is constant, shouldn't happen
_manager.addMessage("Please retry form submission (bad nonce)");
......@@ -320,9 +328,12 @@ public class I2PSnarkServlet extends BasicServlet {
// we want it to go to the base URI so we don't refresh with some funky action= value
int delay = 0;
if (!isConfigure) {
if (isConfigure) {
out.write("<script src=\".resources/js/configui.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n");
} else {
delay = _manager.getRefreshDelaySeconds();
if (delay > 0) {
// init for search even if refresh disabled
//if (delay > 0) {
String jsPfx = _context.isRouterContext() ? "" : ".resources";
String downMsg = _context.isRouterContext() ? _t("Router is down") : _t("I2PSnark has stopped");
// fallback to metarefresh when javascript is disabled
......@@ -333,13 +344,16 @@ public class I2PSnarkServlet extends BasicServlet {
"var ajaxDelay = " + (delay * 1000) + ";\n" +
"</script>\n" +
"<script src=\".resources/js/initajax.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n");
}
//}
out.write("<script nonce=\"" + cspNonce + "\" type=\"text/javascript\">\n" +
"var deleteMessage1 = \"" + _t("Are you sure you want to delete the file \\''{0}\\'' (downloaded data will not be deleted) ?") + "\";\n" +
"var deleteMessage2 = \"" + _t("Are you sure you want to delete the torrent \\''{0}\\'' and all downloaded data?") + "\";\n" +
"</script>\n" +
"<script src=\".resources/js/delete.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n");
"<script src=\".resources/js/delete.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n" +
"<script src=\".resources/js/search.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n" +
"<script src=\".resources/js/dnd.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n");
}
out.write("<script src=\"/js/iframeResizer.contentWindow.js?" + CoreVersion.VERSION + "\" type=\"text/javascript\"></script>\n");
out.write(HEADER_A + _themePath + HEADER_B);
// ...and inject CSS to display panels uncollapsed
......@@ -362,7 +376,7 @@ public class I2PSnarkServlet extends BasicServlet {
else
out.write(_contextName);
if (!_context.isRouterContext()) {
out.write(' ' + CoreVersion.VERSION);
out.write(' ' + SnarkManager.FULL_VERSION);
}
out.write("</a>");
List<Tracker> sortedTrackers = null;
......@@ -374,15 +388,30 @@ public class I2PSnarkServlet extends BasicServlet {
continue;
if (_manager.util().isKnownOpenTracker(t.announceURL))
continue;
out.write(" <a href=\"" + t.baseURL + "\" class=\"snarkNav nav_tracker\" target=\"_blank\">" + t.name + "</a>");
out.write(" <a href=\"" + t.baseURL + "\" class=\"snarkNav nav_tracker\" target=\"_blank\">" + t.name + "</a>\n");
}
}
}
// end snarkNavBar
out.write("</div>\n");
if (!isConfigure) {
String search = req.getParameter("nf_s");
if (_manager.getTorrents().size() > 1 || (search != null && search.length() > 0)) {
out.write("<form class=\"search\" id = \"search\" action=\"" + _contextPath + "\" method=\"GET\">" +
"<input type=\"text\" name=\"nf_s\" size=\"20\" class=\"search\" id=\"searchbox\"");
if (search != null)
out.write(" value=\"" + DataHelper.escapeHTML(search) + '"');
out.write(">" +
"<a class=\"cancel\" id=\"searchcancel\" href=\"" + _contextPath + "/\"></a>" +
"</form>\n");
}
}
String newURL = req.getParameter("newURL");
if (newURL != null && newURL.trim().length() > 0 && req.getMethod().equals("GET"))
_manager.addMessage(_t("Click \"Add torrent\" button to fetch torrent"));
out.write("<div class=\"page\"><div id=\"mainsection\" class=\"mainsection\">");
out.write("<div id=\"page\" class=\"page\"><div id=\"mainsection\" class=\"mainsection\">");
writeMessages(out, isConfigure, peerString);
......@@ -484,6 +513,17 @@ public class I2PSnarkServlet extends BasicServlet {
boolean isDegraded = ua != null && ServletUtil.isTextBrowser(ua);
boolean noThinsp = isDegraded || (ua != null && ua.startsWith("Opera"));
// search
boolean isSearch = false;
String search = req.getParameter("nf_s");
if (search != null && search.length() > 0) {
List<Snark> matches = search(search, snarks);
if (matches != null) {
snarks = matches;
isSearch = true;
}
}
// pages
int start = 0;
int total = snarks.size();
......@@ -739,6 +779,8 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(_t("Unreadable") + ": " + DataHelper.escapeHTML(dd.toString()));
} else if (!canWrite) {
out.write(_t("No write permissions for data directory") + ": " + DataHelper.escapeHTML(dd.toString()));
} else if (isSearch) {
out.write(_t("No torrents found."));
} else {
out.write(_t("No torrents loaded."));
}
......@@ -799,6 +841,7 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(' ');
out.write(_t("Dht Debug"));
out.write("</label><div id=\"dhtDebugInner\">");
out.write(_manager.getBandwidthListener().toString());
out.write(dht.renderStatusHTML());
out.write("</div></div></th>");
}
......@@ -813,6 +856,48 @@ public class I2PSnarkServlet extends BasicServlet {
return start == 0;
}
/**
* search torrents for matching terms
*
* @param search non-null and %-encoded, will be decoded here
* @param snarks unmodified, order will be honored
* @return null if not a valid search, or matching torrents in same order, possibly empty
* @since 0.9.58
*/
private static List<Snark> search(String search, Collection<Snark> snarks) {
try {
search = decodePath(search);
} catch (IOException ioe) {
return null;
}
List<String> searchList = null;
String[] terms = DataHelper.split(search, " ");
for (int i = 0; i < terms.length; i++) {
String term = terms[i];
if (term.length() > 0) {
if (searchList == null)
searchList = new ArrayList<String>(4);
searchList.add(Normalizer.normalize(term.toLowerCase(Locale.US), Normalizer.Form.NFKD));
}
}
if (searchList == null)
return null;
List<Snark> matches = new ArrayList<Snark>(32);
for (Snark snark : snarks) {
String lcname = Normalizer.normalize(snark.getBaseName().toLowerCase(Locale.US), Normalizer.Form.NFKD);
// search for any term (OR)
for (int j = 0; j < searchList.size(); j++) {
String term = searchList.get(j);
if (lcname.contains(term)) {
matches.add(snark);
break;
}
}
}
return matches;
}
/**
* hidden inputs for nonce and paramters p, st, and sort
*
......@@ -823,7 +908,7 @@ public class I2PSnarkServlet extends BasicServlet {
private void writeHiddenInputs(PrintWriter out, HttpServletRequest req, String action) {
StringBuilder buf = new StringBuilder(256);
writeHiddenInputs(buf, req, action);
out.write(buf.toString());
out.append(buf);
}
/**
......@@ -854,11 +939,19 @@ public class I2PSnarkServlet extends BasicServlet {
if (action != null) {
buf.append("<input type=\"hidden\" name=\"action\" value=\"")
.append(action).append("\" >\n");
} else {
// for buttons, keep the search term
String sParam = req.getParameter("nf_s");
if (sParam != null) {
buf.append("<input type=\"hidden\" name=\"nf_s\" value=\"")
.append(DataHelper.escapeHTML(sParam)).append("\" >\n");
}
}
}
/**
* Build HTML-escaped and stripped query string
* Build HTML-escaped and stripped query string.
* Keeps any existing search param.
*
* @param p override or "" for default or null to keep the same as in req
* @param st override or "" for default or null to keep the same as in req
......@@ -867,6 +960,14 @@ public class I2PSnarkServlet extends BasicServlet {
* @since 0.9.16
*/
private static String getQueryString(HttpServletRequest req, String p, String st, String so) {
return getQueryString(req, p, st, so, null);
}
/**
* @param s search param override or "" for default or null to keep the same as in req
* @since 0.9.58
*/
private static String getQueryString(HttpServletRequest req, String p, String st, String so, String s) {
StringBuilder buf = new StringBuilder(64);
if (p == null) {
p = req.getParameter("p");
......@@ -899,6 +1000,18 @@ public class I2PSnarkServlet extends BasicServlet {
buf.append("&amp;st=");
buf.append(st);
}
if (s == null) {
s = req.getParameter("nf_s");
if (s != null)
s = DataHelper.escapeHTML(s);
}
if (s != null && !s.equals("")) {
if (buf.length() <= 0)
buf.append("?nf_s=");
else
buf.append("&amp;nf_s=");
buf.append(s);
}
return buf.toString();
}
......@@ -1003,44 +1116,87 @@ public class I2PSnarkServlet extends BasicServlet {
// return;
//}
if ("Add".equals(action)) {
String newURL = req.getParameter("nofilter_newURL");
/******
// NOTE - newFile currently disabled in HTML form - see below
File f = null;
if ( (newFile != null) && (newFile.trim().length() > 0) )
f = new File(newFile.trim());
if ( (f != null) && (!f.exists()) ) {
_manager.addMessage(_t("Torrent file {0} does not exist", newFile));
File dd = _manager.getDataDir();
if (!dd.canWrite()) {
_manager.addMessage(_t("No write permissions for data directory") + ": " + dd);
return;
}
if ( (f != null) && (f.exists()) ) {
// NOTE - All this is disabled - load from local file disabled
File local = new File(_manager.getDataDir(), f.getName());
String canonical = null;
try {
canonical = local.getCanonicalPath();
if (local.exists()) {
if (_manager.getTorrent(canonical) != null)
_manager.addMessage(_t("Torrent already running: {0}", newFile));
else
_manager.addMessage(_t("Torrent already in the queue: {0}", newFile));
} else {
boolean ok = FileUtil.copy(f.getAbsolutePath(), local.getAbsolutePath(), true);
if (ok) {
_manager.addMessage(_t("Copying torrent to {0}", local.getAbsolutePath()));
_manager.addTorrent(canonical);
} else {
_manager.addMessage(_t("Unable to copy the torrent to {0}", local.getAbsolutePath()) + ' ' + _t("from {0}", f.getAbsolutePath()));
String contentType = req.getContentType();
RequestWrapper reqw = new RequestWrapper(req);
String newURL = reqw.getParameter("nofilter_newURL");
String newFile = reqw.getFilename("newFile");
if (newFile != null && newFile.trim().length() > 0) {
if (!newFile.endsWith(".torrent"))
newFile += ".torrent";
File local = new File(dd, newFile);
String newFile2 = Storage.filterName(newFile);
File local2;
if (!newFile.equals(newFile2)) {
local2 = new File(dd, newFile2);
} else {
local2 = null;
}
if (local.exists() || (local2 != null && local2.exists())) {
try {
String canonical = local.getCanonicalPath();
String canonical2 = local2 != null ? local2.getCanonicalPath() : null;
if (_manager.getTorrent(canonical) != null ||
(canonical2 != null && _manager.getTorrent(canonical2) != null))
_manager.addMessage(_t("Torrent already running: {0}", canonical));
else
_manager.addMessage(_t("Torrent already in the queue: {0}", canonical));
} catch (IOException ioe) {}
} else {
File tmp = new File(_manager.util().getTempDir(), "newTorrent-" + _manager.util().getContext().random().nextLong() + ".torrent");
InputStream in = null;
OutputStream out = null;
try {
in = reqw.getInputStream("newFile");
out = new SecureFileOutputStream(tmp);
DataHelper.copy(in, out);
out.close();
out = null;
in.close();
// test that it's a valid torrent file, and get the hash to check for dups
in = new FileInputStream(tmp);
byte[] fileInfoHash = new byte[20];
String name = MetaInfo.getNameAndInfoHash(in, fileInfoHash);
try { in.close(); } catch (IOException ioe) {}
Snark snark = _manager.getTorrentByInfoHash(fileInfoHash);
if (snark != null) {
_manager.addMessage(_t("Torrent with this info hash is already running: {0}", snark.getBaseName()));
return;
}
if (local2 != null)
local = local2;
String canonical = local.getCanonicalPath();
// This may take a LONG time to create the storage.
boolean ok = _manager.copyAndAddTorrent(tmp, canonical, dd);
if (!ok)
throw new IOException("Unknown error - check logs");
snark = _manager.getTorrentByInfoHash(fileInfoHash);
if (snark != null)
snark.startTorrent();
else
throw new IOException("Not found: " + canonical);
} catch (IOException ioe) {
_manager.addMessageNoEscape(_t("Torrent at {0} was not valid", DataHelper.escapeHTML(newFile)) + ": " + DataHelper.stripHTML(ioe.getMessage()));
tmp.delete();
local.delete();
if (local2 != null)
local2.delete();
return;
} catch (OutOfMemoryError oom) {
_manager.addMessageNoEscape(_t("ERROR - Out of memory, cannot create torrent from {0}", DataHelper.escapeHTML(newFile)) + ": " + DataHelper.stripHTML(oom.getMessage()));
} finally {
if (in != null) try { in.close(); } catch (IOException ioe) {}
if (out != null) try { out.close(); } catch (IOException ioe) {}
tmp.delete();
}
} catch (IOException ioe) {
_log.warn("hrm: " + local, ioe);
}
} else
*****/
if (newURL != null) {
} else if (newURL != null && newURL.trim().length() > 0) {
newURL = newURL.trim();
String newDir = req.getParameter("nofilter_newDir");
String newDir = reqw.getParameter("nofilter_newDir");
File dir = null;
if (newDir != null) {
newDir = newDir.trim();
......@@ -1068,11 +1224,6 @@ public class I2PSnarkServlet extends BasicServlet {
}
}
}
File dd = _manager.getDataDir();
if (!dd.canWrite()) {
_manager.addMessage(_t("No write permissions for data directory") + ": " + dd);
return;
}
if (newURL.startsWith("http://") || newURL.startsWith("https://")) {
if (isI2PTracker(newURL)) {
FetchAndAdd fetch = new FetchAndAdd(_context, _manager, newURL, dir);
......@@ -1136,7 +1287,7 @@ public class I2PSnarkServlet extends BasicServlet {
boolean ok = _manager.copyAndAddTorrent(file, canonical, dd);
if (!ok)
throw new IOException("Unknown error - check logs");
snark = _manager.getTorrentByBaseName(originalName);
snark = _manager.getTorrentByInfoHash(fileInfoHash);
if (snark != null)
snark.startTorrent();
else
......@@ -1156,6 +1307,7 @@ public class I2PSnarkServlet extends BasicServlet {
}
} else {
// no file or URL specified
_manager.addMessage(_t("Enter URL or select torrent file"));
}
} else if (action.startsWith("Stop_")) {
String torrent = action.substring(5);
......@@ -1307,6 +1459,7 @@ public class I2PSnarkServlet extends BasicServlet {
String i2cpOpts = buildI2CPOpts(req);
String upLimit = req.getParameter("upLimit");
String upBW = req.getParameter("upBW");
String downBW = req.getParameter("downBW");
String refreshDel = req.getParameter("refreshDelay");
String startupDel = req.getParameter("startupDelay");
String pageSize = req.getParameter("pageSize");
......@@ -1322,7 +1475,7 @@ public class I2PSnarkServlet extends BasicServlet {
boolean collapsePanels = req.getParameter("collapsePanels") != null;
_manager.updateConfig(dataDir, filesPublic, autoStart, smartSort, refreshDel, startupDel, pageSize,
seedPct, eepHost, eepPort, i2cpHost, i2cpPort, i2cpOpts,
upLimit, upBW, useOpenTrackers, useDHT, theme,
upLimit, upBW, downBW, useOpenTrackers, useDHT, theme,
lang, ratings, comments, commentsName, collapsePanels);
// update servlet
try {
......@@ -1335,6 +1488,9 @@ public class I2PSnarkServlet extends BasicServlet {
} else if ("Create".equals(action)) {
String baseData = req.getParameter("nofilter_baseFile");
if (baseData != null && baseData.trim().length() > 0) {
// drag and drop, no js
if (baseData.startsWith("file://"))
baseData = baseData.substring(7);
File baseFile = new File(baseData.trim());
if (!baseFile.isAbsolute())
baseFile = new File(_manager.getDataDir(), baseData);
......@@ -1453,8 +1609,36 @@ public class I2PSnarkServlet extends BasicServlet {
_manager.addMessage(_t("Error creating torrent - you must enter a file or directory"));
}
} else if ("StopAll".equals(action)) {
String search = req.getParameter("nf_s");
if (search != null && search.length() > 0) {
List<Snark> matches = search(search, _manager.getTorrents());
if (matches != null) {
for (Snark snark : matches) {
_manager.stopTorrent(snark, false);
}
return;
}
}
_manager.stopAllTorrents(false);
} else if ("StartAll".equals(action)) {
String search = req.getParameter("nf_s");
if (search != null && search.length() > 0) {
List<Snark> matches = search(search, _manager.getTorrents());
if (matches != null) {
// TODO thread it
int count = 0;
for (Snark snark : matches) {
if (!snark.isStopped())
continue;
_manager.startTorrent(snark);
if ((count++ & 0x0f) == 15) {
// try to prevent OOMs
try { Thread.sleep(250); } catch (InterruptedException ie) {}
}
}
return;
}
}
_manager.startAllTorrents();
} else if ("Clear".equals(action)) {
String sid = req.getParameter("id");
......@@ -1760,7 +1944,7 @@ public class I2PSnarkServlet extends BasicServlet {
":</b> " + curPeers + thinsp(noThinsp) +
ngettext("1 peer", "{0} peers", knownPeers);
} else if (isRunning && curPeers > 0 && !showPeers) {
statusString = toThemeImg("stalled", "", _t("Stalled") + " (" + ngettext("Connected to {0} peer", "Connected to {0} peers", curPeers)) + "</td>" +
statusString = toThemeImg("stalled", "", _t("Stalled") + " (" + ngettext("Connected to {0} peer", "Connected to {0} peers", curPeers) + ")") + "</td>" +
"<td class=\"snarkTorrentStatus\"><b>" + _t("Stalled") +
":</b> <a href=\"" + uri + getQueryString(req, b64, null, null) + '#' + b64Short + "\">" +
curPeers + thinsp(noThinsp) +
......@@ -1811,7 +1995,7 @@ public class I2PSnarkServlet extends BasicServlet {
buf.append("<a href=\"").append(encodedBaseName)
.append("/\" title=\"").append(_t("Torrent details"))
.append("\">");
out.write(buf.toString());
out.append(buf);
}
String icon;
if (isMultiFile)
......@@ -1840,7 +2024,7 @@ public class I2PSnarkServlet extends BasicServlet {
.append("\">");
toThemeImg(buf, "comment", "", "");
buf.append("</a>");
out.write(buf.toString());
out.append(buf);
}
}
......@@ -1864,7 +2048,7 @@ public class I2PSnarkServlet extends BasicServlet {
else
buf.append(_t("Open file"));
buf.append("\">");
out.write(buf.toString());
out.append(buf);
}
out.write(DataHelper.escapeHTML(basename));
if (remaining == 0 || isMultiFile)
......@@ -2002,30 +2186,75 @@ public class I2PSnarkServlet extends BasicServlet {
if (ch.startsWith("WebSeed@")) {
out.write(ch);
} else {
// most clients start -xx, see
// BT spec or libtorrent identify_client.cpp
// Base64 encode -xx
// Anything starting with L is -xx and has an Az version
// snark is 9 nulls followed by 3 3 3 (binary), see Snark
// PeerID.toString() skips nulls
// Base64 encode '\3\3\3' = AwMD
boolean addVersion = true;
ch = ch.substring(0, 4);
String client;
if ("AwMD".equals(ch))
client = _t("I2PSnark");
else if ("LUJJ".equals(ch))
client = "BiglyBT" + getAzVersion(pid.getID());
client = "BiglyBT";
else if ("LUFa".equals(ch))
client = "Vuze" + getAzVersion(pid.getID());
client = "Vuze";
else if ("LVhE".equals(ch))
client = "XD" + getAzVersion(pid.getID());
else if ("ZV".equals(ch.substring(2,4)) || "VUZP".equals(ch))
client = "Robert" + getRobtVersion(pid.getID());
client = "XD";
else if (ch.startsWith("LV")) // LVCS 1.0.2?; LVRS 1.0.4
client = "Transmission" + getAzVersion(pid.getID());
client = "Transmission";
else if ("LUtU".equals(ch))
client = "KTorrent" + getAzVersion(pid.getID());
client = "KTorrent";
else if ("LUVU".equals(ch)) // ET
client = "EepTorrent";
// libtorrent and downstreams
// https://www.libtorrent.org/projects.html
else if ("LURF".equals(ch)) // DL
client = "Deluge";
else if ("LXFC".equals(ch)) // qB
client = "qBittorrent";
else if ("LUxU".equals(ch)) // LT
client = "libtorrent";
// ancient below here
else if ("ZV".equals(ch.substring(2,4)) || "VUZP".equals(ch))
client = "Robert" + getRobtVersion(pid.getID());
else if ("CwsL".equals(ch))
client = "I2PSnarkXL";
else if ("BFJT".equals(ch))
client = "I2PRufus";
else if ("TTMt".equals(ch))
client = "I2P-BT";
else
client = _t("Unknown") + " (" + ch + ')';
else {
// get client + version from handshake
client = null;
Map<String, BEValue> handshake = peer.getHandshakeMap();
if (handshake != null) {
BEValue bev = handshake.get("v");
if (bev != null) {
try {
String s = bev.getString();
if (s.length() > 0) {
if (s.length() > 64)
s = s.substring(0, 64);
client = DataHelper.escapeHTML(s);
addVersion = false;
}
} catch (InvalidBEncodingException ibee) {}
}
}
if (client == null)
client = _t("Unknown") + " (" + ch + ')';
}
if (addVersion) {
byte[] id = pid.getID();
if (id != null && id[0] == '-')
client += getAzVersion(id);
}
out.write(client + "&nbsp;<tt title=\"");
out.write(_t("Destination (identity) of peer"));
out.write("\">" + peer.toString().substring(5, 9)+ "</tt>");
......@@ -2289,12 +2518,9 @@ public class I2PSnarkServlet extends BasicServlet {
newURL = "";
else
newURL = DataHelper.stripHTML(newURL); // XSS
//String newFile = req.getParameter("newFile");
//if ( (newFile == null) || (newFile.trim().length() <= 0) ) newFile = "";
out.write("<div id=\"add\" class=\"snarkNewTorrent\">\n" +
// *not* enctype="multipart/form-data", so that the input type=file sends the filename, not the file
"<form action=\"_post\" method=\"POST\">\n");
"<form action=\"_post\" method=\"POST\" enctype=\"multipart/form-data\" accept-charset=\"UTF-8\">\n");
writeHiddenInputs(out, req, "Add");
out.write("<div class=\"addtorrentsection\">" +
"<input class=\"toggle_input\" id=\"toggle_addtorrent\" type=\"checkbox\"");
......@@ -2310,19 +2536,20 @@ public class I2PSnarkServlet extends BasicServlet {
out.write("<hr>\n<table border=\"0\"><tr><td>");
out.write(_t("From URL"));
out.write(":<td><input type=\"text\" name=\"nofilter_newURL\" size=\"85\" value=\"" + newURL + "\" spellcheck=\"false\"" +
out.write(":<td><input type=\"text\" id=\"nofilter_newURL\" name=\"nofilter_newURL\" size=\"85\" value=\"" + newURL + "\" spellcheck=\"false\"" +
" title=\"");
out.write(_t("Enter the torrent file download URL (I2P only), magnet link, or info hash"));
out.write("\">\n");
// not supporting from file at the moment, since the file name passed isn't always absolute (so it may not resolve)
//out.write("From file: <input type=\"file\" name=\"newFile\" size=\"50\" value=\"" + newFile + "\" /><br>");
out.write("<input type=\"submit\" class=\"add\" value=\"");
out.write("<input type=\"submit\" id=\"addButton\" class=\"add\" value=\"");
out.write(_t("Add torrent"));
out.write("\" name=\"foo\" ><br>\n" +
"<tr><td>");
out.write(_t("Torrent file"));
out.write(":<td><input type=\"file\" name=\"newFile\" id=\"newFile\" accept=\".torrent\"/>\n" +
"<tr><td>");
out.write(_t("Data dir"));
out.write(":<td><input type=\"text\" name=\"nofilter_newDir\" size=\"85\" value=\"\" spellcheck=\"false\"" +
out.write(":<td><input type=\"text\" id=\"nofilter_newDir\" name=\"nofilter_newDir\" size=\"85\" value=\"\" spellcheck=\"false\"" +
" title=\"");
out.write(_t("Enter the directory to save the data in (default {0})", _manager.getDataDir().getAbsolutePath()));
out.write("\"></td></tr>\n");
......@@ -2348,11 +2575,11 @@ public class I2PSnarkServlet extends BasicServlet {
//out.write("From file: <input type=\"file\" name=\"newFile\" size=\"50\" value=\"" + newFile + "\" /><br>\n");
out.write(_t("Data to seed"));
out.write(":<td>"
+ "<input type=\"text\" name=\"nofilter_baseFile\" size=\"85\" value=\""
+ "<input type=\"text\" id=\"nofilter_baseFile\" name=\"nofilter_baseFile\" size=\"85\" value=\""
+ "\" spellcheck=\"false\" title=\"");
out.write(_t("File or directory to seed (full path or within the directory {0} )",
_manager.getDataDir().getAbsolutePath() + File.separatorChar));
out.write("\" > <input type=\"submit\" class=\"create\" value=\"");
out.write("\" > <input type=\"submit\" id=\"createButton\" class=\"create\" value=\"");
out.write(_t("Create torrent"));
out.write("\" name=\"foo\" >" +
"<tr><td>\n");
......@@ -2503,7 +2730,7 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(_t("Theme"));
out.write(":<td colspan=\"2\">");
if (_manager.getUniversalTheming()) {
out.write("<select name='theme' disabled=\"disabled\" title=\"");
out.write("<select id=\"theme\" name=\"theme\" disabled=\"disabled\" title=\"");
out.write(_t("To change themes manually, disable universal theming"));
out.write("\"><option>");
out.write(_manager.getTheme());
......@@ -2513,7 +2740,7 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(_t("Configure"));
out.write("]</a>");
} else {
out.write("<select name='theme'>");
out.write("<select id=\"theme\" name=\"theme\">");
String theme = _manager.getTheme();
String[] themes = _manager.getThemes();
// translated sort
......@@ -2609,7 +2836,7 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(":<td><input type=\"text\" name=\"upBW\" class=\"r\" value=\""
+ _manager.util().getMaxUpBW() + "\" size=\"4\" maxlength=\"4\""
+ " title=\"");
out.write(_t("Maximum bandwidth allocated for uploading"));
out.write(_t("Maximum bandwidth allocated"));
out.write("\"> KBps <td id=\"bwHelp\"><i>");
out.write(_t("Half available bandwidth recommended."));
if (_context.isRouterContext()) {
......@@ -2619,6 +2846,24 @@ public class I2PSnarkServlet extends BasicServlet {
out.write(_t("Configure"));
out.write("]</a>");
}
out.write("\n" +
"<tr><td>");
out.write(_t("Down bandwidth limit"));
out.write(":<td><input type=\"text\" name=\"downBW\" class=\"r\" value=\""
+ (_manager.getBandwidthListener().getDownBWLimit() / 1000) + "\" size=\"4\" maxlength=\"4\""
+ " title=\"");
out.write(_t("Maximum bandwidth allocated"));
out.write("\"> KBps <td id=\"bwHelp\"><i>");
out.write(_t("Half available bandwidth recommended."));
if (_context.isRouterContext()) {
out.write("</i> <a href=\"/config.jsp\" target=\"blank\" title=\"");
out.write(_t("View or change router bandwidth"));
out.write("\">[");
out.write(_t("Configure"));
out.write("]</a>");
}
out.write("\n<tr><td><label for=\"useOpenTrackers\">");
out.write(_t("Use open trackers also"));
out.write(":</label><td colspan=\"2\"><input type=\"checkbox\" class=\"optbox\" name=\"useOpenTrackers\" id=\"useOpenTrackers\" value=\"true\" "
......@@ -2803,7 +3048,7 @@ public class I2PSnarkServlet extends BasicServlet {
"</td></tr>" +
"<tr class=\"spacer\"><td colspan=\"7\">&nbsp;</td></tr>\n" + // spacer
"</table></div></div></form>\n");
out.write(buf.toString());
out.append(buf);
}
private void writeConfigLink(PrintWriter out) throws IOException {
......@@ -2953,8 +3198,8 @@ public class I2PSnarkServlet extends BasicServlet {
return escaped;
}
private static final String DOCTYPE = "<!DOCTYPE HTML PUBLIC \"-//W3C//DTD HTML 4.01 Transitional//EN\">\n";
private static final String HEADER_A = "<link href=\"";
private static final String DOCTYPE = "<!DOCTYPE html>\n";
private static final String HEADER_A = "<link id=\"pagestyle\" href=\"";
private static final String HEADER_B = "snark.css?" + CoreVersion.VERSION + "\" rel=\"stylesheet\" type=\"text/css\" >";
private static final String HEADER_C = "nocollapse.css?" + CoreVersion.VERSION + "\" rel=\"stylesheet\" type=\"text/css\" >";
......@@ -3172,7 +3417,7 @@ public class I2PSnarkServlet extends BasicServlet {
buf.append("</span></td></tr>");
}
List<List<String>> alist = meta.getAnnounceList();
List<String> annlist = new ArrayList<String>();
Set<String> annlist = new TreeSet<String>();
if (alist != null && !alist.isEmpty()) {
// strip non-i2p trackers
for (List<String> alist2 : alist) {
......@@ -4193,11 +4438,11 @@ public class I2PSnarkServlet extends BasicServlet {
MetaInfo meta = snark.getMetaInfo();
if (meta == null)
return;
buf.append("<div id=\"snarkCommentSection\"><table class=\"snarkTorrentInfo\">\n")
buf.append("<div id=\"snarkCommentSection\"><table class=\"snarkTorrentInfo\">\n");
//.append("<tr><th colspan=\"5\">")
//.append(_t("Edit Torrent"))
//.append("</th>")
.append("</tr>");
//.append("</tr>");
boolean isRunning = !snark.isStopped();
if (isRunning) {
// shouldn't happen
......@@ -4228,8 +4473,8 @@ public class I2PSnarkServlet extends BasicServlet {
if (announce != null)
annlist.add(announce);
if (!annlist.isEmpty()) {
buf.append("<tr><td colspan=\"3\"></td><td>").append("Primary").append("</td><td>")
.append("Delete").append("</td></tr>");
buf.append("<tr><td colspan=\"3\"></td><td>").append(_t("Primary")).append("</td><td>")
.append(_t("Delete")).append("</td></tr>");
for (String s : annlist) {
int hc = s.hashCode();
buf.append("<tr><td>");
......@@ -4261,8 +4506,8 @@ public class I2PSnarkServlet extends BasicServlet {
iter.remove();
}
if (!newTrackers.isEmpty()) {
buf.append("<tr><td colspan=\"3\"></td><td>").append("Primary").append("</td><td>")
.append("Add").append("</td></tr>");
buf.append("<tr><td colspan=\"3\"></td><td>").append(_t("Primary")).append("</td><td>")
.append(_t("Add")).append("</td></tr>");
for (Tracker t : newTrackers) {
String name = t.name;
int hc = t.announceURL.hashCode();
......@@ -4645,14 +4890,7 @@ public class I2PSnarkServlet extends BasicServlet {
newComment = null;
if (newCreatedBy.equals(""))
newCreatedBy = null;
MetaInfo newMeta = new MetaInfo(thePrimary, meta.getName(), null, meta.getFiles(), meta.getLengths(),
meta.getPieceLength(0), meta.getPieceHashes(), meta.getTotalLength(), meta.isPrivate(),
newAnnList, newCreatedBy, meta.getWebSeedURLs(), newComment);
if (!DataHelper.eq(meta.getInfoHash(), newMeta.getInfoHash())) {
// shouldn't happen
_manager.addMessage("Torrent edit failed, infohash mismatch");
return;
}
MetaInfo newMeta = new MetaInfo(meta, thePrimary, newAnnList, newComment, newCreatedBy, meta.getWebSeedURLs());
File f = new File(_manager.util().getTempDir(), "edit-" + _manager.util().getContext().random().nextLong() + ".torrent");
OutputStream out = null;
try {
......
......@@ -14,6 +14,10 @@
package org.klomp.snark.web;
import java.io.BufferedReader;
import java.io.FileInputStream;
import java.io.InputStreamReader;
import java.io.IOException;
import java.util.Enumeration;
import java.util.Locale;
import java.util.Map;
......@@ -21,6 +25,9 @@ import java.util.MissingResourceException;
import java.util.ResourceBundle;
import java.util.concurrent.ConcurrentHashMap;
import net.i2p.data.DataHelper;
import net.i2p.util.SystemVersion;
/* ------------------------------------------------------------ */
/**
......@@ -47,6 +54,8 @@ class MimeTypes
public MimeTypes() {
_mimeMap = new ConcurrentHashMap<String, String>();
if (!(SystemVersion.isWindows() || SystemVersion.isMac() || SystemVersion.getMaxMemory() < 100*1024*1024L))
loadSystemMimeTypes();
}
/* ------------------------------------------------------------ */
......@@ -86,6 +95,37 @@ class MimeTypes
}
}
/**
* Load mime types from /etc/mime.types
* Format: mimetype suffix1 suffix2 ...
*
* @since 0.9.54
*/
private void loadSystemMimeTypes() {
BufferedReader in = null;
try {
in = new BufferedReader(new InputStreamReader(new FileInputStream("/etc/mime.types"), "ISO-8859-1"));
while (true) {
String line = in.readLine();
if (line == null)
break;
if (line.startsWith("#"))
continue;
String[] s = DataHelper.split(line, "[ \t]+", 16);
if (s.length < 2)
continue;
for (int i = 1; i < s.length; i++) {
_mimeMap.put(s[i].toLowerCase(Locale.US), s[0]);
//System.out.println("Mapping: '" + s[i] + "' -> '" + s[0] + "'");
}
}
//System.out.println("Loaded " + _mimeMap.size() + " mime types from /etc/mime.types");
} catch (IOException ioe) {
} finally {
if (in != null) try { in.close(); } catch (IOException ioe) {}
}
}
/* ------------------------------------------------------------ */
/** Get the MIME type by filename extension.
*
......
......@@ -4,5 +4,37 @@
# The file jetty-i2psnark.xml must be present in the current directory.
# i2psnark will be accessed at http://127.0.0.1:8002/
#
I2P="."
java -jar "$I2P/i2psnark.jar"
# Raise the soft open files soft ulimit to this value, if able
OPEN_FILES_ULIMIT=2048
# Increase memory to 512 MB
JAVA_OPTS='-Xmx512m'
raiseopenfilesulimit() {
OPEN_FILES_SOFT=`ulimit -S -n` 2> /dev/null || return
if [ "$OPEN_FILES_SOFT" != "unlimited" ]
then
if [ "$OPEN_FILES_ULIMIT" -gt "$OPEN_FILES_SOFT" ]
then
OPEN_FILES_HARD=`ulimit -H -n` 2> /dev/null || return
if [ "$OPEN_FILES_HARD" != "unlimited" ]
then
if [ "$OPEN_FILES_ULIMIT" -gt "$OPEN_FILES_HARD" ]
then
OPEN_FILES_ULIMIT="$OPEN_FILES_HARD"
fi
fi
if [ "$OPEN_FILES_ULIMIT" -gt "$OPEN_FILES_SOFT" ]
then
ulimit -S -n "$OPEN_FILES_ULIMIT" > /dev/null 2>&1
fi
fi
fi
}
raiseopenfilesulimit
I2P="`dirname $0`"
cd "$I2P"
java $JAVA_OPTS -jar i2psnark.jar