All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.hubspot.singularity.data.CuratorAsyncManager Maven / Gradle / Ivy

package com.hubspot.singularity.data;

import com.codahale.metrics.MetricRegistry;
import com.google.common.collect.Lists;
import com.google.common.collect.Maps;
import com.hubspot.singularity.SingularityId;
import com.hubspot.singularity.config.SingularityConfiguration;
import com.hubspot.singularity.data.transcoders.IdTranscoder;
import com.hubspot.singularity.data.transcoders.Transcoder;
import com.hubspot.singularity.data.transcoders.Transcoders;
import java.util.ArrayList;
import java.util.Collection;
import java.util.Collections;
import java.util.HashMap;
import java.util.Iterator;
import java.util.List;
import java.util.Map;
import java.util.Optional;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.CountDownLatch;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicInteger;
import org.apache.curator.framework.CuratorFramework;
import org.apache.curator.framework.api.BackgroundCallback;
import org.apache.curator.framework.api.CuratorEvent;
import org.apache.curator.utils.ZKPaths;
import org.apache.zookeeper.KeeperException;
import org.apache.zookeeper.KeeperException.Code;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

public abstract class CuratorAsyncManager extends CuratorManager {
  private static final Logger LOG = LoggerFactory.getLogger(CuratorAsyncManager.class);

  public CuratorAsyncManager(
    CuratorFramework curator,
    SingularityConfiguration configuration,
    MetricRegistry metricRegistry
  ) {
    super(curator, configuration, metricRegistry);
  }

  private enum CuratorQueryMethod {
    GET_DATA(OperationType.GET_MULTI),
    CHECK_EXISTS(OperationType.CHECK_EXISTS),
    GET_CHILDREN(OperationType.GET_CHILDREN);

    private final OperationType operationType;

    private CuratorQueryMethod(OperationType operationType) {
      this.operationType = operationType;
    }
  }

  private  List getAsyncChildrenThrows(
    final String parent,
    final Transcoder transcoder
  )
    throws Exception {
    try {
      List children = getChildren(parent);
      final List paths = Lists.newArrayListWithCapacity(children.size());

      for (String child : children) {
        paths.add(ZKPaths.makePath(parent, child));
      }

      List result = new ArrayList<>(
        getAsyncThrows(parent, paths, transcoder, Optional.empty()).values()
      );

      return result;
    } catch (Throwable t) {
      throw t;
    }
  }

  private  Map getAsyncThrows(
    final String pathNameForLogs,
    final Collection paths,
    final Transcoder transcoder,
    final Optional> cache
  )
    throws Exception {
    final Map objects = new HashMap<>(paths.size());

    if (cache.isPresent()) {
      for (Iterator itr = paths.iterator(); itr.hasNext();) {
        final String path = itr.next();
        final Optional fromCache = cache.get().get(path);
        if (fromCache.isPresent()) {
          objects.put(path, fromCache.get());
          itr.remove();
        }
      }
    }

    if (paths.isEmpty()) {
      return objects;
    }

    final Map synchronizedObjects = Collections.synchronizedMap(objects);

    final CountDownLatch latch = new CountDownLatch(paths.size());
    final AtomicInteger bytes = new AtomicInteger();

    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getData() == null || event.getData().length == 0) {
            LOG.trace("Expected active node {} but it wasn't there", event.getPath());
            return;
          }

          bytes.getAndAdd(event.getData().length);
          final T object = transcoder.fromBytes(event.getData());
          synchronizedObjects.put(event.getPath(), object);

          if (cache.isPresent()) {
            cache.get().set(event.getPath(), object);
          }
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      objects,
      paths,
      callback,
      latch,
      pathNameForLogs,
      bytes,
      CuratorQueryMethod.GET_DATA
    );
  }

  private void checkLatch(CountDownLatch latch, String path) throws InterruptedException {
    if (!latch.await(configuration.getZookeeperAsyncTimeout(), TimeUnit.MILLISECONDS)) {
      throw new IllegalStateException(
        String.format(
          "Timed out waiting response for objects from %s, waited %s millis",
          path,
          configuration.getZookeeperAsyncTimeout()
        ),
        KeeperException.create(Code.OPERATIONTIMEOUT, path)
      );
    }
  }

  private  List getChildrenAsIdsForParentsThrows(
    final String pathNameforLogs,
    final Collection parents,
    final IdTranscoder idTranscoder
  )
    throws Exception {
    if (parents.isEmpty()) {
      return Collections.emptyList();
    }

    final List objects = Lists.newArrayListWithExpectedSize(parents.size());
    final List synchronizedObjects = Collections.synchronizedList(objects);

    final CountDownLatch latch = new CountDownLatch(parents.size());

    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getChildren() == null || event.getChildren().size() == 0) {
            LOG.trace("Expected children for node {} - but found none", event.getPath());
            return;
          }
          synchronizedObjects.addAll(
            Lists.transform(
              event.getChildren(),
              Transcoders.getFromStringFunction(idTranscoder)
            )
          );
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      synchronizedObjects,
      parents,
      callback,
      latch,
      pathNameforLogs,
      new AtomicInteger(),
      CuratorQueryMethod.GET_CHILDREN
    );
  }

  protected  List getChildrenAsIdsForParents(
    final String pathNameforLogs,
    final Collection parents,
    final IdTranscoder idTranscoder
  ) {
    try {
      return getChildrenAsIdsForParentsThrows(pathNameforLogs, parents, idTranscoder);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getChildrenAsIds(
    final String rootPath,
    final IdTranscoder idTranscoder
  ) {
    return Lists.transform(
      getChildren(rootPath),
      Transcoders.getFromStringFunction(idTranscoder)
    );
  }

  private  List existsThrows(
    final String pathNameforLogs,
    final Collection paths,
    final IdTranscoder idTranscoder
  )
    throws Exception {
    if (paths.isEmpty()) {
      return Collections.emptyList();
    }

    final List objects = Lists.newArrayListWithCapacity(paths.size());

    final CountDownLatch latch = new CountDownLatch(paths.size());

    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getStat() != null) {
            objects.add(
              Transcoders
                .getFromStringFunction(idTranscoder)
                .apply(ZKPaths.getNodeFromPath(event.getPath()))
            );
          }
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      objects,
      paths,
      callback,
      latch,
      pathNameforLogs,
      new AtomicInteger(),
      CuratorQueryMethod.GET_DATA
    );
  }

  protected  List exists(
    final String pathNameForLogs,
    final Collection paths,
    final IdTranscoder idTranscoder
  ) {
    try {
      return existsThrows(pathNameForLogs, paths, idTranscoder);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  private  List notExistsThrows(
    final String pathNameforLogs,
    final Map pathsMap
  )
    throws Exception {
    if (pathsMap.isEmpty()) {
      return Collections.emptyList();
    }

    final List objects = Lists.newArrayListWithCapacity(pathsMap.size());

    final CountDownLatch latch = new CountDownLatch(pathsMap.size());

    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getStat() == null) {
            objects.add(pathsMap.get(event.getPath()));
          }
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      objects,
      pathsMap.keySet(),
      callback,
      latch,
      pathNameforLogs,
      new AtomicInteger(),
      CuratorQueryMethod.CHECK_EXISTS
    );
  }

  protected  List notExists(
    final String pathNameForLogs,
    final Map pathsMap
  ) {
    try {
      return notExistsThrows(pathNameForLogs, pathsMap);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getAsync(
    final String pathNameForLogs,
    final Collection paths,
    final Transcoder transcoder,
    final ZkCache cache
  ) {
    try {
      return new ArrayList<>(
        getAsyncThrows(pathNameForLogs, paths, transcoder, Optional.of(cache)).values()
      );
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getAsync(
    final String pathNameForLogs,
    final Collection paths,
    final Transcoder transcoder
  ) {
    try {
      return new ArrayList<>(
        getAsyncThrows(pathNameForLogs, paths, transcoder, Optional.>empty())
          .values()
      );
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  Map getAsyncWithPath(
    final String pathNameForLogs,
    final Collection paths,
    final Transcoder transcoder
  ) {
    try {
      return getAsyncThrows(
        pathNameForLogs,
        paths,
        transcoder,
        Optional.>empty()
      );
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getAsyncChildren(
    final String parent,
    final Transcoder transcoder
  ) {
    try {
      return getAsyncChildrenThrows(parent, transcoder);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getAsyncNestedChildrenAsListThrows(
    final String pathNameForLogs,
    final List parentPaths,
    final Transcoder transcoder
  )
    throws Exception {
    final List allPaths = new ArrayList<>();
    for (String parent : parentPaths) {
      for (String child : getChildren(parent)) {
        allPaths.add(ZKPaths.makePath(parent, child));
      }
    }

    final List results = new ArrayList<>();
    final CountDownLatch latch = new CountDownLatch(allPaths.size());
    final AtomicInteger bytes = new AtomicInteger();
    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getData() == null || event.getData().length == 0) {
            LOG.trace("Expected active node {} but it wasn't there", event.getPath());
            return;
          }
          bytes.getAndAdd(event.getData().length);

          final T object = transcoder.fromBytes(event.getData());

          results.add(object);
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      results,
      allPaths,
      callback,
      latch,
      pathNameForLogs,
      bytes,
      CuratorQueryMethod.GET_DATA
    );
  }

  protected  List getAsyncNestedChildrenAsList(
    final String pathNameForLogs,
    final List parentPaths,
    final Transcoder transcoder
  ) {
    try {
      return getAsyncNestedChildrenAsListThrows(pathNameForLogs, parentPaths, transcoder);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  Map> getAsyncNestedChildDataAsMapThrows(
    final String pathNameForLogs,
    final Map parentPathsMap,
    final String subpath,
    final Transcoder transcoder
  )
    throws Exception {
    final Map allPathsMap = Maps.newHashMap();
    for (Map.Entry entry : parentPathsMap.entrySet()) {
      for (String child : getChildren(ZKPaths.makePath(entry.getKey(), subpath))) {
        allPathsMap.put(
          ZKPaths.makePath(entry.getKey(), subpath, child),
          entry.getValue()
        );
      }
    }

    final ConcurrentHashMap> resultsMap = new ConcurrentHashMap<>();
    final CountDownLatch latch = new CountDownLatch(allPathsMap.size());
    final AtomicInteger bytes = new AtomicInteger();
    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          if (event.getData() == null || event.getData().length == 0) {
            LOG.trace("Expected active node {} but it wasn't there", event.getPath());
            return;
          }
          bytes.getAndAdd(event.getData().length);

          final Q object = transcoder.fromBytes(event.getData());

          if (allPathsMap.get(event.getPath()) != null) {
            resultsMap.putIfAbsent(allPathsMap.get(event.getPath()), new ArrayList());
            resultsMap.get(allPathsMap.get(event.getPath())).add(object);
          }
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      resultsMap,
      allPathsMap.keySet(),
      callback,
      latch,
      pathNameForLogs,
      bytes,
      CuratorQueryMethod.GET_DATA
    );
  }

  protected  Map> getAsyncNestedChildDataAsMap(
    final String pathNameForLogs,
    final Map parentPathsMap,
    final String subpath,
    final Transcoder transcoder
  ) {
    try {
      return getAsyncNestedChildDataAsMapThrows(
        pathNameForLogs,
        parentPathsMap,
        subpath,
        transcoder
      );
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  protected  List getAsyncNestedChildIdsAsListThrows(
    final String pathNameForLogs,
    final String parentPath,
    final IdTranscoder transcoder
  )
    throws Exception {
    final List allPaths = new ArrayList<>();
    for (String child : getChildren(parentPath)) {
      allPaths.add(ZKPaths.makePath(parentPath, child));
    }

    final List results = new ArrayList<>();
    final CountDownLatch latch = new CountDownLatch(allPaths.size());
    final AtomicInteger bytes = new AtomicInteger();
    final BackgroundCallback callback = new BackgroundCallback() {

      @Override
      public void processResult(CuratorFramework client, CuratorEvent event)
        throws Exception {
        try {
          event
            .getChildren()
            .forEach(
              child -> {
                final T object = transcoder.fromString(child);
                bytes.getAndAdd(child.getBytes().length);
                results.add(object);
              }
            );
        } finally {
          latch.countDown();
        }
      }
    };

    return queryAndReturnResultsThrows(
      results,
      allPaths,
      callback,
      latch,
      pathNameForLogs,
      bytes,
      CuratorQueryMethod.GET_CHILDREN
    );
  }

  protected  List getAsyncNestedChildIdsAsList(
    final String pathNameForLogs,
    final String parentPath,
    final IdTranscoder transcoder
  ) {
    try {
      return getAsyncNestedChildIdsAsListThrows(pathNameForLogs, parentPath, transcoder);
    } catch (Throwable t) {
      throw new RuntimeException(t);
    }
  }

  private  T queryAndReturnResultsThrows(
    final T results,
    final Collection paths,
    final BackgroundCallback callback,
    final CountDownLatch latch,
    final String pathNameForLogs,
    final AtomicInteger bytes,
    final CuratorQueryMethod method
  )
    throws Exception {
    final long start = System.currentTimeMillis();

    try {
      for (String path : paths) {
        switch (method) {
          case GET_DATA:
            curator.getData().inBackground(callback).forPath(path);
            break;
          case GET_CHILDREN:
            curator.getChildren().inBackground(callback).forPath(path);
            break;
          case CHECK_EXISTS:
          default:
            curator.checkExists().inBackground(callback).forPath(path);
            break;
        }
      }

      checkLatch(latch, pathNameForLogs);
    } finally {
      log(
        method.operationType,
        Optional.of(paths.size()),
        bytes.get() > 0 ? Optional.of(bytes.get()) : Optional.empty(),
        start,
        pathNameForLogs
      );
    }

    return results;
  }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy