Rename tests to livetest in kamaki.clients
[kamaki] / kamaki / clients / pithos.py
index 35ebaac..e8b4b6d 100644 (file)
@@ -1,4 +1,4 @@
-# Copyright 2011-2012 GRNET S.A. All rights reserved.
+# Copyright 2011-2013 GRNET S.A. All rights reserved.
 #
 # Redistribution and use in source and binary forms, with or
 # without modification, are permitted provided that the following
 # interpreted as representing official policies, either expressed
 # or implied, of GRNET S.A.
 
-import gevent
-import gevent.monkey
-# Monkey-patch everything for gevent early on
-gevent.monkey.patch_all()
-import gevent.pool
+from threading import enumerate as activethreads
 
-from os import fstat, path
+from os import fstat
 from hashlib import new as newhashlib
-from time import time, sleep
-from datetime import datetime
-import sys
+from time import time
 
 from binascii import hexlify
-from .pithos_sh_lib.hashmap import HashMap
 
-from .pithos_rest_api import PithosRestAPI
-from .storage import ClientError
-from .utils import path4url, filter_in
+from kamaki.clients import SilentEvent, sendlog
+from kamaki.clients.pithos_rest_api import PithosRestAPI
+from kamaki.clients.storage import ClientError
+from kamaki.clients.utils import path4url, filter_in
+from StringIO import StringIO
 
-def pithos_hash(block, blockhash):
+
+def _pithos_hash(block, blockhash):
     h = newhashlib(blockhash)
     h.update(block.rstrip('\x00'))
     return h.hexdigest()
 
+
+def _range_up(start, end, a_range):
+    if a_range:
+        (rstart, rend) = a_range.split('-')
+        (rstart, rend) = (int(rstart), int(rend))
+        if rstart > end or rend < start:
+            return (0, 0)
+        if rstart > start:
+            start = rstart
+        if rend < end:
+            end = rend
+    return (start, end)
+
+
 class PithosClient(PithosRestAPI):
     """GRNet Pithos API client"""
 
-    def __init__(self, base_url, token, account=None, container = None):
-        super(PithosClient, self).__init__(base_url, token, account = account,
-            container = container)
-        self.async_pool = None
+    _thread_exceptions = []
+
+    def __init__(self, base_url, token, account=None, container=None):
+        super(PithosClient, self).__init__(base_url, token, account, container)
 
     def purge_container(self):
-        self.container_delete(until=unicode(time()))
-        
-    def upload_object_unchunked(self, obj, f, withHashFile = False, size=None, etag=None,
-        content_encoding=None, content_disposition=None, content_type=None, sharing=None,
-        public=None):
-        # This is a naive implementation, it loads the whole file in memory
-        #Look in pithos for a nice implementation
-        self.assert_container()
+        """Delete an empty container and destroy associated blocks
+        """
+        r = self.container_delete(until=unicode(time()))
+        r.release()
+
+    def upload_object_unchunked(
+            self, obj, f,
+            withHashFile=False,
+            size=None,
+            etag=None,
+            content_encoding=None,
+            content_disposition=None,
+            content_type=None,
+            sharing=None,
+            public=None):
+        """
+        :param obj: (str) remote object path
+
+        :param f: open file descriptor
+
+        :param withHashFile: (bool)
+
+        :param size: (int) size of data to upload
+
+        :param etag: (str)
+
+        :param content_encoding: (str)
+
+        :param content_disposition: (str)
+
+        :param content_type: (str)
+
+        :param sharing: {'read':[user and/or grp names],
+            'write':[usr and/or grp names]}
+
+        :param public: (bool)
+        """
+        self._assert_container()
 
         if withHashFile:
             data = f.read()
@@ -79,48 +119,79 @@ class PithosClient(PithosRestAPI):
                 import json
                 data = json.dumps(json.loads(data))
             except ValueError:
-                raise ClientError(message='"%s" is not json-formated'%f.name, status=1)
+                raise ClientError('"%s" is not json-formated' % f.name, 1)
             except SyntaxError:
-                raise ClientError(message='"%s" is not a valid hashmap file'%f.name, status=1)
-            from StringIO import StringIO
+                msg = '"%s" is not a valid hashmap file' % f.name
+                raise ClientError(msg, 1)
             f = StringIO(data)
         data = f.read(size) if size is not None else f.read()
-        self.object_put(obj, data=data, etag=etag, content_encoding=content_encoding,
-            content_disposition=content_disposition, content_type=content_type, permitions=sharing,
-            public=public, success=201)
-        
-    def put_block_async(self, data, hash):
-        class SilentGreenlet(gevent.Greenlet):
-            def _report_error(self, exc_info):
-                _stderr = None
-                try:
-                    _stderr = sys._stderr
-                    sys.stderr = StringIO()
-                    gevent.Greenlet._report_error(self, exc_info)
-                finally:
-                    sys.stderr = _stderr
-        POOL_SIZE = 5
-        if self.async_pool is None:
-            self.async_pool = gevent.pool.Pool(size=POOL_SIZE)
-        g = SilentGreenlet(self.put_block, data, hash)
-        self.async_pool.start(g)
-        return g
-
-    def put_block(self, data, hash):
-        r = self.container_post(update=True, content_type='application/octet-stream',
-            content_length=len(data), data=data, format='json')
+        r = self.object_put(
+            obj,
+            data=data,
+            etag=etag,
+            content_encoding=content_encoding,
+            content_disposition=content_disposition,
+            content_type=content_type,
+            permissions=sharing,
+            public=public,
+            success=201)
+        r.release()
+
+    def create_object_by_manifestation(
+            self, obj,
+            etag=None,
+            content_encoding=None,
+            content_disposition=None,
+            content_type=None,
+            sharing=None,
+            public=None):
+        """
+        :param obj: (str) remote object path
+
+        :param etag: (str)
+
+        :param content_encoding: (str)
+
+        :param content_disposition: (str)
+
+        :param content_type: (str)
+
+        :param sharing: {'read':[user and/or grp names],
+            'write':[usr and/or grp names]}
+
+        :param public: (bool)
+        """
+        self._assert_container()
+        r = self.object_put(
+            obj,
+            content_length=0,
+            etag=etag,
+            content_encoding=content_encoding,
+            content_disposition=content_disposition,
+            content_type=content_type,
+            permissions=sharing,
+            public=public,
+            manifest='%s/%s' % (self.container, obj))
+        r.release()
+
+    # upload_* auxiliary methods
+    def _put_block_async(self, data, hash, upload_gen=None):
+        event = SilentEvent(method=self._put_block, data=data, hash=hash)
+        event.start()
+        return event
+
+    def _put_block(self, data, hash):
+        from random import randint
+        if not randint(0, 7):
+            raise ClientError('BAD GATEWAY STUFF', 503)
+        r = self.container_post(
+            update=True,
+            content_type='application/octet-stream',
+            content_length=len(data),
+            data=data,
+            format='json')
         assert r.json[0] == hash, 'Local hash does not match server'
-        
-
-    def create_object_by_manifestation(self, obj, etag=None, content_encoding=None,
-        content_disposition=None, content_type=None, sharing=None, public=None):
-        self.assert_container()
-        obj_content_type = 'application/octet-stream' if content_type is None else content_type
-        self.object_put(obj, content_length=0, etag=etag, content_encoding=content_encoding,
-            content_disposition=content_disposition, content_type=content_type, permitions=sharing,
-            public=public, manifest='%s/%s'%(self.container,obj))
-       
-    #upload_* auxiliary methods 
+
     def _get_file_block_info(self, fileobj, size=None):
         meta = self.get_container_info()
         blocksize = int(meta['x-container-block-size'])
@@ -129,20 +200,39 @@ class PithosClient(PithosRestAPI):
         nblocks = 1 + (size - 1) // blocksize
         return (blocksize, blockhash, size, nblocks)
 
-    def _get_missing_hashes(self, obj, json, size=None, format='json', hashmap=True,
-        content_type=None, etag=None, content_encoding=None, content_disposition=None,
-        permitions=None, public=None, success=(201, 409)):
-        r = self.object_put(obj, format='json', hashmap=True, content_type=content_type,
-            json=json, etag=etag, content_encoding=content_encoding,
-            content_disposition=content_disposition, permitions=permitions, public=public,
+    def _get_missing_hashes(
+            self, obj, json,
+            size=None,
+            format='json',
+            hashmap=True,
+            content_type=None,
+            etag=None,
+            content_encoding=None,
+            content_disposition=None,
+            permissions=None,
+            public=None,
+            success=(201, 409)):
+        r = self.object_put(
+            obj,
+            format='json',
+            hashmap=True,
+            content_type=content_type,
+            json=json,
+            etag=etag,
+            content_encoding=content_encoding,
+            content_disposition=content_disposition,
+            permissions=permissions,
+            public=public,
             success=success)
         if r.status_code == 201:
+            r.release()
             return None
         return r.json
 
-    def _caclulate_uploaded_blocks(self, blocksize, blockhash, size, nblocks, hashes, hmap, fileobj,
-        hash_cb=None):
-        offset=0
+    def _caclulate_uploaded_blocks(
+            self, blocksize, blockhash, size, nblocks, hashes, hmap, fileobj,
+            hash_cb=None):
+        offset = 0
         if hash_cb:
             hash_gen = hash_cb(nblocks)
             hash_gen.next()
@@ -150,209 +240,340 @@ class PithosClient(PithosRestAPI):
         for i in range(nblocks):
             block = fileobj.read(min(blocksize, size - offset))
             bytes = len(block)
-            hash = pithos_hash(block, blockhash)
+            hash = _pithos_hash(block, blockhash)
             hashes.append(hash)
             hmap[hash] = (offset, bytes)
             offset += bytes
             if hash_cb:
                 hash_gen.next()
-        assert offset == size
+        msg = 'Failed to calculate uploaded blocks:'
+        msg += ' Offset and object size do not match'
+        assert offset == size, msg
 
-    def _upload_missing_blocks(self, missing, hmap, fileobj, upload_cb=None):
-        """upload missing blocks asynchronously in a pseudo-parallel fashion (greenlets)
-        """
-        if upload_cb:
-            upload_gen = upload_cb(len(missing))
-            upload_gen.next()
+    def _upload_missing_blocks(self, missing, hmap, fileobj, upload_gen=None):
+        """upload missing blocks asynchronously"""
+
+        self._init_thread_limit()
 
         flying = []
+        failures = []
         for hash in missing:
             offset, bytes = hmap[hash]
             fileobj.seek(offset)
             data = fileobj.read(bytes)
-            r = self.put_block_async(data, hash)
+            r = self._put_block_async(data, hash, upload_gen)
             flying.append(r)
-            for r in flying:
-                if r.ready():
-                    if r.exception:
-                        raise r.exception
-                    if upload_cb:
+            unfinished = self._watch_thread_limit(flying)
+            for thread in set(flying).difference(unfinished):
+                if thread.exception:
+                    failures.append(thread)
+                    if isinstance(
+                            thread.exception,
+                            ClientError) and thread.exception.status == 502:
+                        self.POOLSIZE = self._thread_limit
+                elif thread.isAlive():
+                    flying.append(thread)
+                elif upload_gen:
+                    try:
                         upload_gen.next()
-            flying = [r for r in flying if not r.ready()]
-        while upload_cb:
-            try:
-                upload_gen.next()
-            except StopIteration:
-                break
-        gevent.joinall(flying)
+                    except:
+                        pass
+            flying = unfinished
+
+        for thread in flying:
+            thread.join()
+            if thread.exception:
+                failures.append(thread)
+            elif upload_gen:
+                try:
+                    upload_gen.next()
+                except:
+                    pass
+
+        return [failure.kwargs['hash'] for failure in failures]
+
+    def upload_object(
+            self, obj, f,
+            size=None,
+            hash_cb=None,
+            upload_cb=None,
+            etag=None,
+            content_encoding=None,
+            content_disposition=None,
+            content_type=None,
+            sharing=None,
+            public=None):
+        """Upload an object using multiple connections (threads)
+
+        :param obj: (str) remote object path
+
+        :param f: open file descriptor (rb)
+
+        :param hash_cb: optional progress.bar object for calculating hashes
+
+        :param upload_cb: optional progress.bar object for uploading
+
+        :param etag: (str)
+
+        :param content_encoding: (str)
 
-    def upload_object(self, obj, f, size=None, hash_cb=None, upload_cb=None, etag=None,
-        content_encoding=None, content_disposition=None, content_type=None, sharing=None,
-        public=None):
-        self.assert_container()
+        :param content_disposition: (str)
+
+        :param content_type: (str)
+
+        :param sharing: {'read':[user and/or grp names],
+            'write':[usr and/or grp names]}
+
+        :param public: (bool)
+        """
+        self._assert_container()
 
         #init
-        block_info = (blocksize, blockhash, size, nblocks) = self._get_file_block_info(f, size)
+        block_info = (blocksize, blockhash, size, nblocks) =\
+            self._get_file_block_info(f, size)
         (hashes, hmap, offset) = ([], {}, 0)
-        content_type = 'application/octet-stream' if content_type is None else content_type
-
-        self._caclulate_uploaded_blocks(*block_info, hashes=hashes, hmap=hmap, fileobj=f,
+        if content_type is None:
+            content_type = 'application/octet-stream'
+
+        self._caclulate_uploaded_blocks(
+            *block_info,
+            hashes=hashes,
+            hmap=hmap,
+            fileobj=f,
             hash_cb=hash_cb)
 
         hashmap = dict(bytes=size, hashes=hashes)
-        missing = self._get_missing_hashes(obj, hashmap, content_type=content_type, size=size,
-            etag=etag, content_encoding=content_encoding, content_disposition=content_disposition,
-            permitions=sharing, public=public)
+        missing = self._get_missing_hashes(
+            obj, hashmap,
+            content_type=content_type,
+            size=size,
+            etag=etag,
+            content_encoding=content_encoding,
+            content_disposition=content_disposition,
+            permissions=sharing,
+            public=public)
 
         if missing is None:
             return
-        self._upload_missing_blocks(missing, hmap, f, upload_cb=upload_cb)
 
-        self.object_put(obj, format='json', hashmap=True, content_type=content_type, 
-            json=hashmap, success=201)
-    
-    #download_* auxiliary methods
+        if upload_cb:
+            upload_gen = upload_cb(len(missing))
+            for i in range(len(missing), len(hashmap['hashes']) + 1):
+                try:
+                    upload_gen.next()
+                except:
+                    upload_gen = None
+        else:
+            upload_gen = None
+
+        retries = 7
+        try:
+            while retries:
+                sendlog.info('%s blocks missing' % len(missing))
+                num_of_blocks = len(missing)
+                missing = self._upload_missing_blocks(
+                    missing,
+                    hmap,
+                    f,
+                    upload_gen)
+                if missing:
+                    if num_of_blocks == len(missing):
+                        retries -= 1
+                    else:
+                        num_of_blocks = len(missing)
+                else:
+                    break
+            if missing:
+                raise ClientError(
+                    '%s blocks failed to upload' % len(missing),
+                    status=800)
+        except KeyboardInterrupt:
+            sendlog.info('- - - wait for threads to finish')
+            for thread in activethreads():
+                thread.join()
+            raise
+
+        r = self.object_put(
+            obj,
+            format='json',
+            hashmap=True,
+            content_type=content_type,
+            json=hashmap,
+            success=201)
+        r.release()
+
+    # download_* auxiliary methods
     def _get_remote_blocks_info(self, obj, **restargs):
         #retrieve object hashmap
+        myrange = restargs.pop('data_range', None)
         hashmap = self.get_object_hashmap(obj, **restargs)
+        restargs['data_range'] = myrange
         blocksize = int(hashmap['block_size'])
         blockhash = hashmap['block_hash']
         total_size = hashmap['bytes']
-        print('total_size:%s, blocksize:%s, x/y:%s, len:%s'%(total_size, blocksize,
-            total_size/blocksize + 1, len(hashmap['hashes'])))
         #assert total_size/blocksize + 1 == len(hashmap['hashes'])
         map_dict = {}
         for i, h in enumerate(hashmap['hashes']):
             map_dict[h] = i
         return (blocksize, blockhash, total_size, hashmap['hashes'], map_dict)
 
-    def _dump_blocks_sync(self, obj, remote_hashes, blocksize, total_size, dst, **restargs):
+    def _dump_blocks_sync(
+            self, obj, remote_hashes, blocksize, total_size, dst, range,
+            **args):
         for blockid, blockhash in enumerate(remote_hashes):
-            if blockhash == None:
-                continue
-            start = blocksize*blockid
-            end = total_size-1 if start+blocksize > total_size else start+blocksize-1
-            restargs['data_range'] = 'bytes=%s-%s'%(start, end)
-            r = self.object_get(obj, success=(200, 206), **restargs)
-            self._cb_next()
-            dst.write(r.content)
-            dst.flush()
-
-    def _filter_out_downloaded_hashses(self, remote_hashes, hash_list, local_file, blocksize,
-        blockhash):
-        #load file hashmap
-        file_hashmap = HashMap(blocksize, blockhash)
-        file_hashmap.load(local_file, hasattr(self, 'progress_bar_gen'))
-
-        for i, x in enumerate(file_hashmap):
-            local_hash = hexlify(x)
-            if local_hash in remote_hashes:
-                blockid = remote_hashes.pop(local_hash)
-                hash_list[blockid] = None
+            if blockhash:
+                start = blocksize * blockid
+                is_last = start + blocksize > total_size
+                end = (total_size - 1) if is_last else (start + blocksize - 1)
+                (start, end) = _range_up(start, end, range)
+                args['data_range'] = 'bytes=%s-%s' % (start, end)
+                r = self.object_get(obj, success=(200, 206), **args)
                 self._cb_next()
-            else:
-                raise ClientError(message='Local file is substantialy different', status=600)
-
-    def _get_block_async(self, obj, **restargs):
-        class SilentGreenlet(gevent.Greenlet):
-            def _report_error(self, exc_info):
-                _stderr = sys._stderr
-                try:
-                    sys.stderr = StringIO()
-                    gevent.Greenlet._report_error(self, exc_info)
-                finally:
-                    sys.stderr = _stderr
-        if not hasattr(self, 'POOL_SIZE'):
-            self.POOL_SIZE = 5
-        if self.async_pool is None:
-            self.async_pool = gevent.pool.Pool(size=self.POOL_SIZE)
-        g = SilentGreenlet(self.object_get, obj, success=(200, 206), **restargs)
-        self.async_pool.start(g)
-        return g
-
-    def _greenlet2file(self, flying_greenlets, local_file, broken={}, **restargs):
+                dst.write(r.content)
+                dst.flush()
+
+    def _get_block_async(self, obj, **args):
+        event = SilentEvent(self.object_get, obj, success=(200, 206), **args)
+        event.start()
+        return event
+
+    def _hash_from_file(self, fp, start, size, blockhash):
+        fp.seek(start)
+        block = fp.read(size)
+        h = newhashlib(blockhash)
+        h.update(block.strip('\x00'))
+        return hexlify(h.digest())
+
+    def _thread2file(self, flying, local_file, offset=0, **restargs):
+        """write the results of a greenleted rest call to a file
+
+        :param offset: the offset of the file up to blocksize
+        - e.g. if the range is 10-100, all blocks will be written to
+        normal_position - 10
+        """
         finished = []
-        for start, g in flying_greenlets.items():
-            print('\tIs g ID(%s) ready? %s'%(self.mmaapp[start], g.ready()))
-            if g.ready():
+        for i, (start, g) in enumerate(flying.items()):
+            if not g.isAlive():
                 if g.exception:
                     raise g.exception
-                try:
-                    block = g.value.content
-                except AttributeError:
-                    broken[start] = flying_greenlets.pop(start)
-                    #g.spawn()
-                    continue
-                local_file.seek(start)
-                print('\tID(%s) [%s...]\n\tg.value:%s\n\tg:%s\n'%(self.mmaapp[start], block[1:10],
-                    g.value, g))
-                print('\tID(%s): g.value.request: %s\n---'%(self.mmaapp[start], g.value.request))
+                block = g.value.content
+                local_file.seek(start - offset)
                 local_file.write(block)
-                #local_file.flush()
                 self._cb_next()
-                finished.append(flying_greenlets.pop(start))
+                finished.append(flying.pop(start))
         local_file.flush()
         return finished
 
-    def _dump_blocks_async(self, obj, remote_hashes, blocksize, total_size, local_file, **restargs):
-        flying_greenlets = {}
-        finished_greenlets = []
-        broken = {}
-        self.mmaapp = {}
+    def _dump_blocks_async(
+            self, obj, remote_hashes, blocksize, total_size, local_file,
+            blockhash=None, resume=False, filerange=None, **restargs):
+        file_size = fstat(local_file.fileno()).st_size if resume else 0
+        flying = {}
+        finished = []
+        offset = 0
+        if filerange is not None:
+            rstart = int(filerange.split('-')[0])
+            offset = rstart if blocksize > rstart else rstart % blocksize
+
+        self._init_thread_limit()
         for block_hash, blockid in remote_hashes.items():
-            if len(flying_greenlets) >= self.POOL_SIZE:
-                finished_greenlets += self._greenlet2file(flying_greenlets, local_file, broken,
-                    **restargs)
-            start = blocksize*blockid
-            self.mmaapp[start] = blockid
-            end = total_size-1 if start+blocksize > total_size else start+blocksize-1
-            restargs['async_headers'] = dict(data_range='bytes=%s-%s'%(start, end))
-            print('ID(%s) get_grnlt {'%blockid)
-            flying_greenlets[start] = self._get_block_async(obj, **restargs)
-            print('ID(%s) got_grnlt }'%blockid)
-
-        #check the greenlets
-        while len(flying_greenlets) > 0:
-            sleep(0.1)
-            finished_greenlets += self._greenlet2file(flying_greenlets, local_file, broken,
+            start = blocksize * blockid
+            if start < file_size and block_hash == self._hash_from_file(
+                    local_file, start, blocksize, blockhash):
+                self._cb_next()
+                continue
+            self._watch_thread_limit(flying.values())
+            finished += self._thread2file(
+                flying,
+                local_file,
+                offset,
                 **restargs)
+            end = total_size - 1 if start + blocksize > total_size\
+                else start + blocksize - 1
+            (start, end) = _range_up(start, end, filerange)
+            if start == end:
+                self._cb_next()
+                continue
+            restargs['async_headers'] = {'Range': 'bytes=%s-%s' % (start, end)}
+            flying[start] = self._get_block_async(obj, **restargs)
+
+        for thread in flying.values():
+            thread.join()
+        finished += self._thread2file(flying, local_file, offset, **restargs)
+
+    def download_object(
+            self, obj, dst,
+            download_cb=None,
+            version=None,
+            resume=False,
+            range_str=None,
+            if_match=None,
+            if_none_match=None,
+            if_modified_since=None,
+            if_unmodified_since=None):
+        """Download an object (multiple connections, random blocks)
 
-        gevent.joinall(finished_greenlets)
+        :param obj: (str) remote object path
 
+        :param dst: open file descriptor (wb+)
 
-    def download_object(self, obj, dst, download_cb=None, version=None, overide=False, resume=False,
-        range=None, if_match=None, if_none_match=None, if_modified_since=None,
-        if_unmodified_since=None):
+        :param download_cb: optional progress.bar object for downloading
 
-        #init REST api args
-        restargs=dict(version=version,
-            data_range = None if range is None else 'bytes=%s'%range,
+        :param version: (str) file version
+
+        :param resume: (bool) if set, preserve already downloaded file parts
+
+        :param range_str: (str) from, to are file positions (int) in bytes
+
+        :param if_match: (str)
+
+        :param if_none_match: (str)
+
+        :param if_modified_since: (str) formated date
+
+        :param if_unmodified_since: (str) formated date"""
+        restargs = dict(
+            version=version,
+            data_range=None if range_str is None else 'bytes=%s' % range_str,
             if_match=if_match,
             if_none_match=if_none_match,
             if_modified_since=if_modified_since,
             if_unmodified_since=if_unmodified_since)
 
-        #1. get remote object hash info
-        (   blocksize,
+        (
+            blocksize,
             blockhash,
             total_size,
-            hash_list, 
+            hash_list,
             remote_hashes) = self._get_remote_blocks_info(obj, **restargs)
         assert total_size >= 0
-        self.POOL_SIZE = 5
 
         if download_cb:
-            self.progress_bar_gen = download_cb(len(remote_hashes)+1)
+            self.progress_bar_gen = download_cb(len(remote_hashes))
             self._cb_next()
 
         if dst.isatty():
-            self._dump_blocks_sync(obj, hash_list, blocksize, total_size, dst, **restargs)
-        elif resume:
-            self._filter_out_downloaded_hashses(remote_hashes, hash_list, dst, blocksize, blockhash)
-            self._dump_blocks_sync(obj, hash_list, blocksize, total_size, dst, **restargs)
+            self._dump_blocks_sync(
+                obj,
+                hash_list,
+                blocksize,
+                total_size,
+                dst,
+                range_str,
+                **restargs)
         else:
-            self._dump_blocks_async(obj, remote_hashes, blocksize, total_size, dst, **restargs)
-            dst.truncate(total_size)
+            self._dump_blocks_async(
+                obj,
+                remote_hashes,
+                blocksize,
+                total_size,
+                dst,
+                blockhash,
+                resume,
+                range_str,
+                **restargs)
+            if not range_str:
+                dst.truncate(total_size)
 
         self._complete_cb()
 
@@ -363,6 +584,7 @@ class PithosClient(PithosRestAPI):
                 self.progress_bar_gen.next()
             except:
                 pass
+
     def _complete_cb(self):
         while True:
             try:
@@ -370,12 +592,40 @@ class PithosClient(PithosRestAPI):
             except:
                 break
 
-    def get_object_hashmap(self, obj, version=None, if_match=None, if_none_match=None,
-        if_modified_since=None, if_unmodified_since=None, data_range=None):
+    def get_object_hashmap(
+            self, obj,
+            version=None,
+            if_match=None,
+            if_none_match=None,
+            if_modified_since=None,
+            if_unmodified_since=None,
+            data_range=None):
+        """
+        :param obj: (str) remote object path
+
+        :param if_match: (str)
+
+        :param if_none_match: (str)
+
+        :param if_modified_since: (str) formated date
+
+        :param if_unmodified_since: (str) formated date
+
+        :param data_range: (str) from-to where from and to are integers
+            denoting file positions in bytes
+
+        :returns: (list)
+        """
         try:
-            r = self.object_get(obj, hashmap=True, version=version, if_etag_match=if_match,
-                if_etag_not_match=if_none_match, if_modified_since=if_modified_since,
-                if_unmodified_since=if_unmodified_since, data_range=data_range)
+            r = self.object_get(
+                obj,
+                hashmap=True,
+                version=version,
+                if_etag_match=if_match,
+                if_etag_not_match=if_none_match,
+                if_modified_since=if_modified_since,
+                if_unmodified_since=if_unmodified_since,
+                data_range=data_range)
         except ClientError as err:
             if err.status == 304 or err.status == 412:
                 return {}
@@ -383,111 +633,301 @@ class PithosClient(PithosRestAPI):
         return r.json
 
     def set_account_group(self, group, usernames):
-        self.account_post(update=True, groups = {group:usernames})
+        """
+        :param group: (str)
+
+        :param usernames: (list)
+        """
+        r = self.account_post(update=True, groups={group: usernames})
+        r.release()
 
     def del_account_group(self, group):
-        self.account_post(update=True, groups={group:[]})
+        """
+        :param group: (str)
+        """
+        r = self.account_post(update=True, groups={group: []})
+        r.release()
 
     def get_account_info(self, until=None):
+        """
+        :param until: (str) formated date
+
+        :returns: (dict)
+        """
         r = self.account_head(until=until)
         if r.status_code == 401:
             raise ClientError("No authorization")
         return r.headers
 
     def get_account_quota(self):
-        return filter_in(self.get_account_info(), 'X-Account-Policy-Quota', exactMatch = True)
+        """
+        :returns: (dict)
+        """
+        return filter_in(
+            self.get_account_info(),
+            'X-Account-Policy-Quota',
+            exactMatch=True)
 
     def get_account_versioning(self):
-        return filter_in(self.get_account_info(), 'X-Account-Policy-Versioning', exactMatch = True)
+        """
+        :returns: (dict)
+        """
+        return filter_in(
+            self.get_account_info(),
+            'X-Account-Policy-Versioning',
+            exactMatch=True)
 
     def get_account_meta(self, until=None):
-        return filter_in(self.get_account_info(until = until), 'X-Account-Meta-')
+        """
+        :meta until: (str) formated date
+
+        :returns: (dict)
+        """
+        return filter_in(self.get_account_info(until=until), 'X-Account-Meta-')
 
     def get_account_group(self):
+        """
+        :returns: (dict)
+        """
         return filter_in(self.get_account_info(), 'X-Account-Group-')
 
     def set_account_meta(self, metapairs):
+        """
+        :param metapairs: (dict) {key1:val1, key2:val2, ...}
+        """
         assert(type(metapairs) is dict)
-        self.account_post(update=True, metadata=metapairs)
+        r = self.account_post(update=True, metadata=metapairs)
+        r.release()
 
     def del_account_meta(self, metakey):
-        self.account_post(update=True, metadata={metakey:''})
+        """
+        :param metakey: (str) metadatum key
+        """
+        r = self.account_post(update=True, metadata={metakey: ''})
+        r.release()
 
     def set_account_quota(self, quota):
-        self.account_post(update=True, quota=quota)
+        """
+        :param quota: (int)
+        """
+        r = self.account_post(update=True, quota=quota)
+        r.release()
 
     def set_account_versioning(self, versioning):
-        self.account_post(update=True, versioning = versioning)
+        """
+        "param versioning: (str)
+        """
+        r = self.account_post(update=True, versioning=versioning)
+        r.release()
 
     def list_containers(self):
+        """
+        :returns: (dict)
+        """
         r = self.account_get()
         return r.json
 
     def del_container(self, until=None, delimiter=None):
-        self.assert_container()
-        r = self.container_delete(until=until, delimiter=delimiter, success=(204, 404, 409))
+        """
+        :param until: (str) formated date
+
+        :param delimiter: (str) with / empty container
+
+        :raises ClientError: 404 Container does not exist
+
+        :raises ClientError: 409 Container is not empty
+        """
+        self._assert_container()
+        r = self.container_delete(
+            until=until,
+            delimiter=delimiter,
+            success=(204, 404, 409))
+        r.release()
         if r.status_code == 404:
-            raise ClientError('Container "%s" does not exist'%self.container, r.status_code)
+            raise ClientError(
+                'Container "%s" does not exist' % self.container,
+                r.status_code)
         elif r.status_code == 409:
-            raise ClientError('Container "%s" is not empty'%self.container, r.status_code)
+            raise ClientError(
+                'Container "%s" is not empty' % self.container,
+                r.status_code)
 
     def get_container_versioning(self, container):
+        """
+        :param container: (str)
+
+        :returns: (dict)
+        """
         self.container = container
-        return filter_in(self.get_container_info(), 'X-Container-Policy-Versioning')
+        return filter_in(
+            self.get_container_info(),
+            'X-Container-Policy-Versioning')
 
     def get_container_quota(self, container):
+        """
+        :param container: (str)
+
+        :returns: (dict)
+        """
         self.container = container
         return filter_in(self.get_container_info(), 'X-Container-Policy-Quota')
 
-    def get_container_info(self, until = None):
-        r = self.container_head(until=until)
+    def get_container_info(self, until=None):
+        """
+        :param until: (str) formated date
+
+        :returns: (dict)
+
+        :raises ClientError: 404 Container not found
+        """
+        try:
+            r = self.container_head(until=until)
+        except ClientError as err:
+            err.details.append('for container %s' % self.container)
+            raise err
         return r.headers
 
-    def get_container_meta(self, until = None):
-        return filter_in(self.get_container_info(until=until), 'X-Container-Meta')
+    def get_container_meta(self, until=None):
+        """
+        :param until: (str) formated date
+
+        :returns: (dict)
+        """
+        return filter_in(
+            self.get_container_info(until=until),
+            'X-Container-Meta')
+
+    def get_container_object_meta(self, until=None):
+        """
+        :param until: (str) formated date
 
-    def get_container_object_meta(self, until = None):
-        return filter_in(self.get_container_info(until=until), 'X-Container-Object-Meta')
+        :returns: (dict)
+        """
+        return filter_in(
+            self.get_container_info(until=until),
+            'X-Container-Object-Meta')
 
     def set_container_meta(self, metapairs):
+        """
+        :param metapairs: (dict) {key1:val1, key2:val2, ...}
+        """
         assert(type(metapairs) is dict)
-        self.container_post(update=True, metadata=metapairs)
-        
+        r = self.container_post(update=True, metadata=metapairs)
+        r.release()
+
     def del_container_meta(self, metakey):
-        self.container_post(update=True, metadata={metakey:''})
+        """
+        :param metakey: (str) metadatum key
+        """
+        r = self.container_post(update=True, metadata={metakey: ''})
+        r.release()
 
     def set_container_quota(self, quota):
-        self.container_post(update=True, quota=quota)
+        """
+        :param quota: (int)
+        """
+        r = self.container_post(update=True, quota=quota)
+        r.release()
 
     def set_container_versioning(self, versioning):
-        self.container_post(update=True, versioning=versioning)
+        """
+        :param versioning: (str)
+        """
+        r = self.container_post(update=True, versioning=versioning)
+        r.release()
 
     def del_object(self, obj, until=None, delimiter=None):
-        self.assert_container()
-        self.object_delete(obj, until=until, delimiter=delimiter)
+        """
+        :param obj: (str) remote object path
+
+        :param until: (str) formated date
+
+        :param delimiter: (str)
+        """
+        self._assert_container()
+        r = self.object_delete(obj, until=until, delimiter=delimiter)
+        r.release()
+
+    def set_object_meta(self, obj, metapairs):
+        """
+        :param obj: (str) remote object path
 
-    def set_object_meta(self, object, metapairs):
+        :param metapairs: (dict) {key1:val1, key2:val2, ...}
+        """
         assert(type(metapairs) is dict)
-        self.object_post(object, update=True, metadata=metapairs)
+        r = self.object_post(obj, update=True, metadata=metapairs)
+        r.release()
 
-    def del_object_meta(self, metakey, object):
-        self.object_post(object, update=True, metadata={metakey:''})
+    def del_object_meta(self, obj, metakey):
+        """
+        :param obj: (str) remote object path
 
-    def publish_object(self, object):
-        self.object_post(object, update=True, public=True)
+        :param metakey: (str) metadatum key
+        """
+        r = self.object_post(obj, update=True, metadata={metakey: ''})
+        r.release()
 
-    def unpublish_object(self, object):
-        self.object_post(object, update=True, public=False)
+    def publish_object(self, obj):
+        """
+        :param obj: (str) remote object path
+
+        :returns: (str) access url
+        """
+        r = self.object_post(obj, update=True, public=True)
+        r.release()
+        info = self.get_object_info(obj)
+        pref, sep, rest = self.base_url.partition('//')
+        base = rest.split('/')[0]
+        newurl = path4url(
+            '%s%s%s' % (pref, sep, base),
+            info['x-object-public'])
+        return newurl[1:]
+
+    def unpublish_object(self, obj):
+        """
+        :param obj: (str) remote object path
+        """
+        r = self.object_post(obj, update=True, public=False)
+        r.release()
 
     def get_object_info(self, obj, version=None):
-        r = self.object_head(obj, version=version)
-        return r.headers
+        """
+        :param obj: (str) remote object path
+
+        :param version: (str)
+
+        :returns: (dict)
+        """
+        try:
+            r = self.object_head(obj, version=version)
+            return r.headers
+        except ClientError as ce:
+            if ce.status == 404:
+                raise ClientError('Object not found', status=404)
+            raise
 
     def get_object_meta(self, obj, version=None):
-        return filter_in(self.get_object_info(obj, version=version), 'X-Object-Meta')
+        """
+        :param obj: (str) remote object path
+
+        :param version: (str)
+
+        :returns: (dict)
+        """
+        return filter_in(
+            self.get_object_info(obj, version=version),
+            'X-Object-Meta')
+
+    def get_object_sharing(self, obj):
+        """
+        :param obj: (str) remote object path
 
-    def get_object_sharing(self, object):
-        r = filter_in(self.get_object_info(object), 'X-Object-Sharing', exactMatch = True)
+        :returns: (dict)
+        """
+        r = filter_in(
+            self.get_object_info(obj),
+            'X-Object-Sharing',
+            exactMatch=True)
         reply = {}
         if len(r) > 0:
             perms = r['x-object-sharing'].split(';')
@@ -500,88 +940,238 @@ class PithosClient(PithosRestAPI):
                 reply[key] = val
         return reply
 
-    def set_object_sharing(self, object, read_permition = False, write_permition = False):
+    def set_object_sharing(
+            self, obj,
+            read_permition=False, write_permition=False):
         """Give read/write permisions to an object.
-           @param object is the object to change sharing permitions onto
-           @param read_permition is a list of users and user groups that get read permition for this object
-                False means all previous read permitions will be removed
-           @param write_perimition is a list of users and user groups to get write permition for this object
-                False means all previous read permitions will be removed
-        """
-        perms = {}
-        perms['read'] = read_permition if isinstance(read_permition, list) else ''
-        perms['write'] = write_permition if isinstance(write_permition, list) else ''
-        self.object_post(object, update=True, permitions=perms)
-
-    def del_object_sharing(self, object):
-        self.set_object_sharing(object)
-
-    def append_object(self, object, source_file, upload_cb = None):
-        """@param upload_db is a generator for showing progress of upload
-            to caller application, e.g. a progress bar. Its next is called
-            whenever a block is uploaded
-        """
-        self.assert_container()
+
+        :param obj: (str) remote object path
+
+        :param read_permition: (list - bool) users and user groups that get
+            read permition for this object - False means all previous read
+            permissions will be removed
+
+        :param write_perimition: (list - bool) of users and user groups to get
+           write permition for this object - False means all previous write
+           permissions will be removed
+        """
+
+        perms = dict(
+            read='' if not read_permition else read_permition,
+            write='' if not write_permition else write_permition)
+        r = self.object_post(obj, update=True, permissions=perms)
+        r.release()
+
+    def del_object_sharing(self, obj):
+        """
+        :param obj: (str) remote object path
+        """
+        self.set_object_sharing(obj)
+
+    def append_object(self, obj, source_file, upload_cb=None):
+        """
+        :param obj: (str) remote object path
+
+        :param source_file: open file descriptor
+
+        :param upload_db: progress.bar for uploading
+        """
+
+        self._assert_container()
         meta = self.get_container_info()
         blocksize = int(meta['x-container-block-size'])
         filesize = fstat(source_file.fileno()).st_size
-        nblocks = 1 + (filesize - 1)//blocksize
+        nblocks = 1 + (filesize - 1) // blocksize
         offset = 0
-        if upload_cb is not None:
+        if upload_cb:
             upload_gen = upload_cb(nblocks)
+            upload_gen.next()
         for i in range(nblocks):
             block = source_file.read(min(blocksize, filesize - offset))
             offset += len(block)
-            self.object_post(object, update=True, content_range='bytes */*',
-                content_type='application/octet-stream', content_length=len(block), data=block)
-            
-            if upload_cb is not None:
+            r = self.object_post(
+                obj,
+                update=True,
+                content_range='bytes */*',
+                content_type='application/octet-stream',
+                content_length=len(block),
+                data=block)
+            r.release()
+
+            if upload_cb:
                 upload_gen.next()
 
-    def truncate_object(self, object, upto_bytes):
-        self.object_post(object, update=True, content_range='bytes 0-%s/*'%upto_bytes,
-            content_type='application/octet-stream', object_bytes=upto_bytes,
-            source_object=path4url(self.container, object))
+    def truncate_object(self, obj, upto_bytes):
+        """
+        :param obj: (str) remote object path
 
-    def overwrite_object(self, object, start, end, source_file, upload_cb=None):
-        """Overwrite a part of an object with given source file
-           @start the part of the remote object to start overwriting from, in bytes
-           @end the part of the remote object to stop overwriting to, in bytes
+        :param upto_bytes: max number of bytes to leave on file
         """
-        self.assert_container()
+        r = self.object_post(
+            obj,
+            update=True,
+            content_range='bytes 0-%s/*' % upto_bytes,
+            content_type='application/octet-stream',
+            object_bytes=upto_bytes,
+            source_object=path4url(self.container, obj))
+        r.release()
+
+    def overwrite_object(self, obj, start, end, source_file, upload_cb=None):
+        """Overwrite a part of an object from local source file
+
+        :param obj: (str) remote object path
+
+        :param start: (int) position in bytes to start overwriting from
+
+        :param end: (int) position in bytes to stop overwriting at
+
+        :param source_file: open file descriptor
+
+        :param upload_db: progress.bar for uploading
+        """
+
+        r = self.get_object_info(obj)
+        rf_size = int(r['content-length'])
+        if rf_size < int(start):
+            raise ClientError(
+                'Range start exceeds file size',
+                status=416)
+        elif rf_size < int(end):
+            raise ClientError(
+                'Range end exceeds file size',
+                status=416)
+        self._assert_container()
         meta = self.get_container_info()
         blocksize = int(meta['x-container-block-size'])
         filesize = fstat(source_file.fileno()).st_size
         datasize = int(end) - int(start) + 1
-        nblocks = 1 + (datasize - 1)//blocksize
+        nblocks = 1 + (datasize - 1) // blocksize
         offset = 0
-        if upload_cb is not None:
+        if upload_cb:
             upload_gen = upload_cb(nblocks)
+            upload_gen.next()
         for i in range(nblocks):
-            block = source_file.read(min(blocksize, filesize - offset, datasize - offset))
+            read_size = min(blocksize, filesize - offset, datasize - offset)
+            block = source_file.read(read_size)
+            r = self.object_post(
+                obj,
+                update=True,
+                content_type='application/octet-stream',
+                content_length=len(block),
+                content_range='bytes %s-%s/*' % (
+                    start + offset,
+                    start + offset + len(block) - 1),
+                data=block)
             offset += len(block)
-            self.object_post(object, update=True, content_type='application/octet-stream', 
-                content_length=len(block), content_range='bytes %s-%s/*'%(start,end), data=block)
-            
-            if upload_cb is not None:
+            r.release()
+
+            if upload_cb:
                 upload_gen.next()
 
-    def copy_object(self, src_container, src_object, dst_container, dst_object=False,
-        source_version = None, public=False, content_type=None, delimiter=None):
-        self.assert_account()
+    def copy_object(
+            self, src_container, src_object, dst_container,
+            dst_object=False,
+            source_version=None,
+            public=False,
+            content_type=None,
+            delimiter=None):
+        """
+        :param src_container: (str) source container
+
+        :param src_object: (str) source object path
+
+        :param dst_container: (str) destination container
+
+        :param dst_object: (str) destination object path
+
+        :param source_version: (str) source object version
+
+        :param public: (bool)
+
+        :param content_type: (str)
+
+        :param delimiter: (str)
+        """
+        self._assert_account()
         self.container = dst_container
         dst_object = dst_object or src_object
         src_path = path4url(src_container, src_object)
-        self.object_put(dst_object, success=201, copy_from=src_path, content_length=0,
-            source_version=source_version, public=public, content_type=content_type,
+        r = self.object_put(
+            dst_object,
+            success=201,
+            copy_from=src_path,
+            content_length=0,
+            source_version=source_version,
+            public=public,
+            content_type=content_type,
             delimiter=delimiter)
+        r.release()
+
+    def move_object(
+            self, src_container, src_object, dst_container,
+            dst_object=False,
+            source_version=None,
+            public=False,
+            content_type=None,
+            delimiter=None):
+        """
+        :param src_container: (str) source container
+
+        :param src_object: (str) source object path
+
+        :param dst_container: (str) destination container
+
+        :param dst_object: (str) destination object path
+
+        :param source_version: (str) source object version
+
+        :param public: (bool)
+
+        :param content_type: (str)
 
-    def move_object(self, src_container, src_object, dst_container, dst_object=False,
-        source_version = None, public=False, content_type=None, delimiter=None):
-        self.assert_account()
+        :param delimiter: (str)
+        """
+        self._assert_account()
         self.container = dst_container
         dst_object = dst_object or src_object
         src_path = path4url(src_container, src_object)
-        self.object_put(dst_object, success=201, move_from=src_path, content_length=0,
-            source_version=source_version, public=public, content_type=content_type,
-            delimiter=delimiter)
\ No newline at end of file
+        r = self.object_put(
+            dst_object,
+            success=201,
+            move_from=src_path,
+            content_length=0,
+            source_version=source_version,
+            public=public,
+            content_type=content_type,
+            delimiter=delimiter)
+        r.release()
+
+    def get_sharing_accounts(self, limit=None, marker=None, *args, **kwargs):
+        """Get accounts that share with self.account
+
+        :param limit: (str)
+
+        :param marker: (str)
+
+        :returns: (dict)
+        """
+        self._assert_account()
+
+        self.set_param('format', 'json')
+        self.set_param('limit', limit, iff=limit is not None)
+        self.set_param('marker', marker, iff=marker is not None)
+
+        path = ''
+        success = kwargs.pop('success', (200, 204))
+        r = self.get(path, *args, success=success, **kwargs)
+        return r.json
+
+    def get_object_versionlist(self, obj):
+        """
+        :param obj: (str) remote object path
+
+        :returns: (list)
+        """
+        self._assert_container()
+        r = self.object_get(obj, format='json', version='list')
+        return r.json['versions']