Examples of Connection

  • 2 ends that can be connected to {@link Gate}.
  • A {@link Path} that provides the path from the first end to the last end @author zxpletran007
  • spark.api.Connection
    A connection to a SPARQL processor. Connections can be used to create commands, get metadata, or be closed.
  • sun.rmi.transport.Connection
  • tv.floe.metronome.classification.neuralnetworks.core.Connection
  • vicazh.hyperpool.stream.Connection
    This class is the superclass of all connections @author Victor Zhigunov @version 0.4.8.3

  • Examples of com.esotericsoftware.kryonet.Connection

            IntSerializer.put(buffer, handler.objectID, true);
          }

          public <T> T readObjectData (ByteBuffer buffer, Class<T> type) {
            int objectID = IntSerializer.get(buffer, true);
            Connection connection = (Connection)Kryo.getContext().get("connection");
            Object object = getRegisteredObject(connection, objectID);
            if (WARN && object == null) warn("kryonet", "Unknown object ID " + objectID + " for connection: " + connection);
            return (T)object;
          }
        });
    View Full Code Here

    Examples of com.facebook.presto.jdbc.internal.jetty.client.api.Connection

            return activeConnections;
        }

        public Connection acquire()
        {
            Connection connection = acquireIdleConnection();
            if (connection == null)
                connection = tryCreate();
            return connection;
        }
    View Full Code Here

    Examples of com.filenet.api.core.Connection

      /*
       * Test method for
       * 'com.google.enterprise.connector.file.filejavawrap.FnConnection.getConnection()'
       */
      public void testGetConnection() throws RepositoryException {
        Connection test = ((FnConnection) conn).getConnection();
        assertNotNull(test);
        assertEquals(TestConnection.uri, test.getURI());
      }
    View Full Code Here

    Examples of com.google.code.http4j.Connection

        connection.connect();
      }
     
      @Test(dependsOnMethods = "connect", expectedExceptions = SocketTimeoutException.class)
      public void setTimeout() throws IOException {
        Connection conn = createConnection();
        conn.setTimeout(1);
        conn.connect();
      }
    View Full Code Here

    Examples of com.googlecode.protobuf.socketrpc.RpcConnectionFactory.Connection

          LOG.info("Starting RPC server");
          try {
            running = true;
            while (running) {
              // Thread blocks here waiting for requests
              Connection connection = rpcConnectionFactory.createConnection();
              if (running && !executor.isShutdown()) {
                if (connection.isClosed()) {
                  // Connection was closed, don't execute
                  try {
                    Thread.sleep(100);
                  } catch (InterruptedException e) {
                    throw new RuntimeException(e);
    View Full Code Here

    Examples of com.gwtext.client.core.Connection

         * Return the Connection object being used by this Proxy.
         *
         * @return the Connection object. This object may be used to subscribe to events on a finer-grained basis.
         */
        public Connection getConnection() {
            return new Connection(getConnection(jsObj));
        }
    View Full Code Here

    Examples of com.hazelcast.nio.Connection

                this.op = op;
            }

            public void sendResponse(Object obj) {
                long callId = op.getCallId();
                Connection conn = op.getConnection();
                if (!sent.compareAndSet(false, true)) {
                    throw new ResponseAlreadySentException("NormalResponse already sent for call: " + callId
                                                    + " to " + conn.getEndPoint() + ", current-response: " + obj);
                }

                NormalResponse response;
                if(!(obj instanceof NormalResponse)){
                    response = new NormalResponse(obj, op.getCallId(),0, op.isUrgent());
    View Full Code Here

    Examples of com.heroku.api.connection.Connection

         * @param username Heroku username.
         * @param password Heroku password.
         * @return An API key that can be used for subsequent API calls.
         */
        public static String obtainApiKey(String username, String password) {
            Connection tmpConn = ConnectionFactory.get();
            LoginVerification verification = tmpConn.execute(new BasicAuthLogin(username, password), null);
            return verification.getApiKey();
        }
    View Full Code Here

    Examples of com.impetus.client.cassandra.thrift.ThriftClientFactory.Connection

                ThriftDataHandler thriftDataHandler = (ThriftDataHandler) cdHandler;

                List<ThriftRow> indexThriftyRows = thriftDataHandler.toIndexThriftRow(node.getData(), entityMetadata,
                        indexColumnFamily);
                Connection conn = thriftClient.getConnection();
                try
                {
                    for (ThriftRow thriftRow : indexThriftyRows)
                    {
                        byte[] rowKey = PropertyAccessorHelper.toBytes(thriftRow.getId(), thriftRow.getId().getClass());

                        // Create Insertion List
                        List<Mutation> insertion_list = new ArrayList<Mutation>();

                        List<Column> thriftColumns = thriftRow.getColumns();
                        List<SuperColumn> thriftSuperColumns = thriftRow.getSuperColumns();
                        if (thriftColumns != null && !thriftColumns.isEmpty())
                        {
                            for (Column column : thriftColumns)
                            {
                                Mutation mut = new Mutation();
                                mut.setColumn_or_supercolumn(new ColumnOrSuperColumn().setColumn(column));
                                insertion_list.add(mut);
                            }
                        }

                        if (thriftSuperColumns != null && !thriftSuperColumns.isEmpty())
                        {
                            for (SuperColumn superColumn : thriftSuperColumns)
                            {
                                Mutation mut = new Mutation();
                                mut.setColumn_or_supercolumn(new ColumnOrSuperColumn().setSuper_column(superColumn));
                                insertion_list.add(mut);
                            }
                        }

                        // Create Mutation Map
                        Map<String, List<Mutation>> columnFamilyValues = new HashMap<String, List<Mutation>>();
                        columnFamilyValues.put(indexColumnFamily, insertion_list);
                        Map<ByteBuffer, Map<String, List<Mutation>>> mulationMap = new HashMap<ByteBuffer, Map<String, List<Mutation>>>();
                        mulationMap.put(ByteBuffer.wrap(rowKey), columnFamilyValues);

                        // Write Mutation map to database
                        conn.getClient().batch_mutate(mulationMap, consistencyLevel);
                    }
                }
                catch (IllegalStateException e)
                {
                    log.error("Unable to insert records into inverted index, Caused by: .", e);
    View Full Code Here

    Examples of com.impetus.kundera.configure.ClientProperties.DataStore.Connection

            {
                DataStore  ds = getDataStore("elasticsearch");
               
                if (ds != null)
                {
                    Connection connection = ds.getConnection();
                    if (connection != null)
                    {
                        Properties properties = connection.getProperties();

                        return properties;
                    }
                }      
                return null;
    View Full Code Here
    TOP
    Copyright © 2018 www.massapi.com. All rights reserved.
    All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.