Uploaded image for project: 'Phoenix'
  1. Phoenix
  2. PHOENIX-3199

ServerCacheClient sends cache to all regions unnecessarily

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 4.8.0
    • 4.9.0, 4.8.2
    • None
    • None

    Description

      The issue is caused by the htable's coprocessorService method,the third parameter endKey is inclusive,not exclusive.When both startKey and endKey are HConstants.EMPTY_START_ROW,the coprocessorService method may send callable to all regions:

       
      coprocessorService(final Class<T> service,byte[] startKey, byte[] endKey, final Batch.Call<T,R> callable)
      

      In the addServerCache method of org.apache.phoenix.cache.ServerCacheClient class, once the first region can pass the if test in line 174, because the startKey of the first region is HConstants.EMPTY_START_ROW, so the key is also HConstants.EMPTY_START_ROW in line 180. When we invoke the htable's coprocessorService method in line 189, the startKey and endKey(Inclusive) parameters are both HConstants.EMPTY_START_ROW,and the htable's coprocessorService method internally uses getKeysAndRegionsInRange method to locate
      [HConstants.EMPTY_START_ROW,HConstants.EMPTY_START_ROW] to all regions, so cache would be sent to all regions :

       
      170  for (HRegionLocation entry : locations) {
      171               // Keep track of servers we've sent to and only send once
      172                byte[] regionStartKey = entry.getRegionInfo().getStartKey();
      173                byte[] regionEndKey = entry.getRegionInfo().getEndKey();
      174               if ( ! servers.contains(entry) && 
      175                        keyRanges.intersectRegion(regionStartKey, regionEndKey,
      176                               cacheUsingTable.getIndexType() == IndexType.LOCAL)) {  
      177                   // Call RPC once per server
      178                   servers.add(entry);
      179                    if (LOG.isDebugEnabled()) {LOG.debug(addCustomAnnotations("Adding cache entry to be sent for " + entry, connection));}
      180                    final byte[] key = entry.getRegionInfo().getStartKey();
      181                    final HTableInterface htable = services.getTable(cacheUsingTableRef.getTable().getPhysicalName().getBytes());
      182                    closeables.add(htable);
      183                    futures.add(executor.submit(new JobCallable<Boolean>() {
      184                      
      185                        @Override
      186                        public Boolean call() throws Exception {
      187                            final Map<byte[], AddServerCacheResponse> results;
      188                            try {
      189                                results = htable.coprocessorService(ServerCachingService.class, key, key, 
      190                                            new Batch.Call<ServerCachingService, AddServerCacheResponse>() {
      

      Attachments

        1. PHOENIX-3199_v9.patch
          3 kB
          James R. Taylor
        2. PHOENIX-3199_v8.patch
          3 kB
          chenglei

        Issue Links

          Activity

            People

              comnetwork chenglei
              comnetwork chenglei
              Votes:
              0 Vote for this issue
              Watchers:
              6 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: