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

com.datastax.driver.dse.DefaultDseSession Maven / Gradle / Ivy

Go to download

A driver for DataStax Enterprise (DSE) and Apache Cassandra 1.2+ clusters that works exclusively with the Cassandra Query Language version 3 (CQL3) and Cassandra's binary protocol, supporting DSE-specific features such as geospatial types, DSE Graph and DSE authentication.

There is a newer version: 2.4.0
Show newest version
/*
 * Copyright DataStax, Inc.
 *
 * This software can be used solely with DataStax Enterprise. Please consult the license at
 * http://www.datastax.com/terms/datastax-dse-driver-license-terms
 */
package com.datastax.driver.dse;

import com.datastax.driver.core.AbstractSession;
import com.datastax.driver.core.AsyncContinuousPagingResult;
import com.datastax.driver.core.CloseFuture;
import com.datastax.driver.core.Cluster;
import com.datastax.driver.core.ContinuousPagingOptions;
import com.datastax.driver.core.ContinuousPagingResult;
import com.datastax.driver.core.ContinuousPagingSession;
import com.datastax.driver.core.GuavaCompatibility;
import com.datastax.driver.core.Host;
import com.datastax.driver.core.PreparedStatement;
import com.datastax.driver.core.RegularStatement;
import com.datastax.driver.core.ResultSet;
import com.datastax.driver.core.ResultSetFuture;
import com.datastax.driver.core.Session;
import com.datastax.driver.core.SimpleStatement;
import com.datastax.driver.core.Statement;
import com.datastax.driver.core.policies.AddressTranslator;
import com.datastax.driver.dse.graph.GraphOptions;
import com.datastax.driver.dse.graph.GraphResultSet;
import com.datastax.driver.dse.graph.GraphStatement;
import com.datastax.driver.dse.graph.SimpleGraphStatement;
import com.google.common.annotations.VisibleForTesting;
import com.google.common.base.Function;
import com.google.common.util.concurrent.AsyncFunction;
import com.google.common.util.concurrent.ListenableFuture;
import com.google.common.util.concurrent.Uninterruptibles;
import java.net.InetSocketAddress;
import java.nio.ByteBuffer;
import java.util.Map;
import java.util.concurrent.ExecutionException;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

/** Default implementation of {@link DseSession} interface. */
class DefaultDseSession extends AbstractSession implements DseSession, ContinuousPagingSession {

  private static final Logger logger = LoggerFactory.getLogger(DefaultDseSession.class);

  private static final String ANALYTICS_GRAPH_SOURCE = "a";
  private static final Statement LOOKUP_ANALYTICS_GRAPH_SERVER =
      new SimpleStatement("CALL DseClientTool.getAnalyticsGraphServer()");

  private final Session delegate;
  private final DseCluster dseCluster;

  DefaultDseSession(Session delegate, DseCluster dseCluster) {
    this.delegate = delegate;
    this.dseCluster = dseCluster;
  }

  @Override
  public DseSession init() {
    try {
      return (DseSession) Uninterruptibles.getUninterruptibly(initAsync());
    } catch (ExecutionException e) {
      throw DriverThrowables.propagateCause(e);
    }
  }

  @Override
  public ListenableFuture initAsync() {
    return GuavaCompatibility.INSTANCE.transform(
        delegate.initAsync(),
        new Function() {
          @Override
          public Session apply(Session input) {
            return DefaultDseSession.this;
          }
        });
  }

  @Override
  public GraphResultSet executeGraph(String query) {
    return executeGraph(new SimpleGraphStatement(query));
  }

  @Override
  public GraphResultSet executeGraph(String query, Map values) {
    return executeGraph(new SimpleGraphStatement(query, values));
  }

  @Override
  public GraphResultSet executeGraph(GraphStatement statement) {
    try {
      return Uninterruptibles.getUninterruptibly(executeGraphAsync(statement));
    } catch (ExecutionException e) {
      throw DriverThrowables.propagateCause(e);
    }
  }

  @Override
  public ListenableFuture executeGraphAsync(String query) {
    return executeGraphAsync(new SimpleGraphStatement(query));
  }

  @Override
  public ListenableFuture executeGraphAsync(
      String query, Map values) {
    return executeGraphAsync(new SimpleGraphStatement(query, values));
  }

  @Override
  public ListenableFuture executeGraphAsync(final GraphStatement graphStatement) {
    final Statement statement =
        generateCoreStatement(dseCluster.getConfiguration().getGraphOptions(), graphStatement);

    if (ANALYTICS_GRAPH_SOURCE.equals(graphStatement.getGraphSource())) {
      // Try to send the statement directly to the graph analytics server (we have to look it up
      // first)
      ListenableFuture serverLocation =
          GuavaCompatibility.INSTANCE.withFallback(
              delegate.executeAsync(LOOKUP_ANALYTICS_GRAPH_SERVER),
              new AsyncFunction() {
                @Override
                public ListenableFuture apply(Throwable t) throws Exception {
                  logger.debug(
                      "Error querying graph analytics server, query will not be routed optimally",
                      t);
                  return null;
                }
              });
      return GuavaCompatibility.INSTANCE.transformAsync(
          serverLocation,
          new AsyncFunction() {
            @Override
            public ListenableFuture apply(ResultSet rs) throws Exception {
              Host analyticsServer = (rs == null) ? null : extractHostFromAnalyticsServerQuery(rs);
              Statement targetedStatement =
                  (analyticsServer == null)
                      ? statement
                      : new HostTargetingStatement(statement, analyticsServer);
              return GuavaCompatibility.INSTANCE.transform(
                  delegate.executeAsync(targetedStatement),
                  new Function() {
                    @Override
                    public GraphResultSet apply(ResultSet input) {
                      return new GraphResultSet(input, graphStatement.getTransformResultFunction());
                    }
                  });
            }
          });
    } else {
      return GuavaCompatibility.INSTANCE.transform(
          delegate.executeAsync(statement),
          new Function() {
            @Override
            public GraphResultSet apply(ResultSet input) {
              return new GraphResultSet(input, graphStatement.getTransformResultFunction());
            }
          });
    }
  }

  private Host extractHostFromAnalyticsServerQuery(ResultSet rs) {
    if (rs.isExhausted()) {
      logger.debug(
          "Empty response querying graph analytics server, query will not be routed optimally");
      return null;
    }

    try {
      Map result = rs.one().getMap("result", String.class, String.class);
      if (result != null && result.containsKey("location")) {
        String location = result.get("location");
        String hostName = location.substring(0, location.lastIndexOf(":"));
        AddressTranslator addressTranslator =
            dseCluster.getConfiguration().getPolicies().getAddressTranslator();
        int port = dseCluster.getConfiguration().getProtocolOptions().getPort();
        InetSocketAddress broadcastRpcAddress =
            addressTranslator.translate(new InetSocketAddress(hostName, port));
        // TODO it would make sense to expose a 'getHostBySocketAddress' in the core to avoid the
        // iteration
        for (Host host : dseCluster.getMetadata().getAllHosts()) {
          if (host.getSocketAddress().equals(broadcastRpcAddress)) {
            logger.debug("Routing analytics query to {}", host);
            return host;
          }
        }
        logger.debug(
            "Could not find host matching graph analytics server {}, query will not be routed optimally",
            broadcastRpcAddress);
        return null;
      }

      logger.debug(
          "Could not extract graph analytics server location from '{}', query will not be routed optimally",
          result);
      return null;

    } catch (Exception e) {
      logger.debug(
          "Error while processing graph analytics server location, query will not be routed optimally",
          e);
      return null;
    }
  }

  /**
   * This method is mainly for internal use, its behaviour is likely to change between driver
   * versions. This method returns a core {@link com.datastax.driver.core.Statement} with all graph
   * settings correctly applied, extracted from the {@link GraphStatement} and {@link GraphOptions}.
   *
   * @param graphOptions the graph options to apply.
   * @param graphStatement the graph statement containing the per-statement options.
   * @return the statement with the correct options applied to.
   */
  @VisibleForTesting
  static Statement generateCoreStatement(GraphOptions graphOptions, GraphStatement graphStatement) {
    Statement statement = graphStatement.unwrap(graphOptions);
    statement.setOutgoingPayload(graphOptions.buildPayloadWithDefaults(graphStatement));

    // Apply graph-options timeout only if not set on statement.
    // Has to be done here since it applies to the core statement and not the custom payload...
    if (statement.getReadTimeoutMillis() == Integer.MIN_VALUE) {
      statement.setReadTimeoutMillis(graphOptions.getReadTimeoutMillis());
    }

    Boolean idempotent = graphStatement.isIdempotent();
    if (idempotent != null) statement.setIdempotent(idempotent);
    return statement;
  }

  @Override
  public DseCluster getCluster() {
    // do not return delegate.getCluster() as this would be
    // an instance of com.datastax.driver.core.Cluster.
    return dseCluster;
  }

  @Override
  public String getLoggedKeyspace() {
    return delegate.getLoggedKeyspace();
  }

  @Override
  public CloseFuture closeAsync() {
    return delegate.closeAsync();
  }

  @Override
  public boolean isClosed() {
    return delegate.isClosed();
  }

  @Override
  public State getState() {
    return delegate.getState();
  }

  @Override
  public ResultSetFuture executeAsync(Statement statement) {
    return delegate.executeAsync(statement);
  }

  @Override
  public ResultSet execute(String query) {
    return delegate.execute(query);
  }

  @Override
  public ResultSet execute(String query, Object... values) {
    return delegate.execute(query, values);
  }

  @Override
  public ResultSet execute(String query, Map values) {
    return delegate.execute(query, values);
  }

  @Override
  public ResultSet execute(Statement statement) {
    return delegate.execute(statement);
  }

  @Override
  public ResultSetFuture executeAsync(String query) {
    return delegate.executeAsync(query);
  }

  @Override
  public ResultSetFuture executeAsync(String query, Object... values) {
    return delegate.executeAsync(query, values);
  }

  @Override
  public ResultSetFuture executeAsync(String query, Map values) {
    return delegate.executeAsync(query, values);
  }

  @Override
  public ListenableFuture executeContinuouslyAsync(
      Statement statement, ContinuousPagingOptions options) {
    return ((ContinuousPagingSession) delegate).executeContinuouslyAsync(statement, options);
  }

  @Override
  public ContinuousPagingResult executeContinuously(
      Statement statement, ContinuousPagingOptions options) {
    return ((ContinuousPagingSession) delegate).executeContinuously(statement, options);
  }

  @Override
  public PreparedStatement prepare(String query) {
    return delegate.prepare(query);
  }

  @Override
  public PreparedStatement prepare(RegularStatement statement) {
    return delegate.prepare(statement);
  }

  @Override
  public ListenableFuture prepareAsync(String query) {
    return delegate.prepareAsync(query);
  }

  @Override
  public ListenableFuture prepareAsync(RegularStatement statement) {
    return delegate.prepareAsync(statement);
  }

  @Override
  public void close() {
    delegate.close();
  }

  @Override
  protected ListenableFuture prepareAsync(
      String query, String keyspace, Map customPayload) {
    throw new IllegalStateException("This method should never be called on DefaultDseSession");
  }

  @Override
  protected Cluster getConcreteCluster() {
    return dseCluster.delegate();
  }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy