Examples of DataStore


Examples of edu.wpi.cs.wpisuitetng.database.DataStore

    this.auth = new BasicAuth();
    this.man = ManagerLayer.getInstance();
    this.sessions = man.getSessions();
   
    // add the test user to the database
    DataStore db = DataStore.getDataStore();
    String hashedPassword = new Sha256Password().generateHash("jayms");
    this.u = new User("Tyler", "twack", hashedPassword, 5);
    db.save(this.u);
  }
View Full Code Here

Examples of hidb2.kern.DataStore

        IRunnableWithProgress op = new IRunnableWithProgress()
          {
            public void run(IProgressMonitor monitor) throws InvocationTargetException, InterruptedException
              {
              int rc = C_OK;
              DataStore das = Application.getDataStore();

              List<FolderSearchResult> lstSR = das.search(_query);
              if (rc == C_OK)
                {
                // Display search results
                for (FolderSearchResult fsr : lstSR)
                  {
                  FolderDescription fd = null;
                  CardDescription cd = null;
                  boolean isCard = false;

                  // Retrieve FolderDescription
                  AttributedDescription ad = das.find(fsr.getTableName());

                  if (ad instanceof CardDescription)
                    {
                    cd = (CardDescription) ad;
                    fd = cd.getParent();
                    isCard = true;
                    }
                  else
                    {
                    if (ad instanceof FolderDescription)
                      {
                      fd = (FolderDescription) ad;
                      }
                    }

                  if (fd != null) // Ignore ListDescription
                    {
                    _cubicView.addFolderDescription(fd);
                    for (int id : fsr.getKeys())
                      {
                      Folder f = isCard ? das.find(cd, id) : das.find(fd, id);

                      _cubicView.addFolder(f);
                      }
                    }
                  }
View Full Code Here

Examples of io.fabric8.api.DataStore

                LOGGER.info("OpenShiftDeployAgent is the master");
            } else {
                LOGGER.info("OpenShiftDeployAgent is not the master");
            }
            try {
                DataStore dataStore = null;
                if (fabricService != null) {
                    dataStore = fabricService.get().adapt(DataStore.class);
                } else {
                    LOGGER.warn("No fabricService yet!");
                }
                if (group.isMaster()) {
                    ControllerNode state = createState();
                    group.update(state);
                }
                if (dataStore != null) {
                    if (group.isMaster()) {
                        dataStore.trackConfiguration(runnable);
                        onConfigurationChanged();
                    } else {
                        dataStore.untrackConfiguration(runnable);
                    }
                }
            } catch (IllegalStateException e) {
                // Ignore
            }
View Full Code Here

Examples of it.eng.spagobi.tools.dataset.common.datastore.DataStore

      logger.debug("Table [" + tableName + "] must be created");
      createTable(baseQuery, tableName, dataSource);
      logger.debug("Table [" + tableName + "] created successfully");
    }
   
    DataStore dataStore = queryTemporaryTable(sqlStatement, tableName, dataSource);
   
    logger.debug("OUT");
    return dataStore;
  }
View Full Code Here

Examples of jade.core.behaviours.DataStore

import jade.lang.acl.ACLMessage;

public class SSIteratedContractNetResponder extends SSContractNetResponder {
 
  public SSIteratedContractNetResponder(Agent a, ACLMessage cfp) {
    this(a, cfp, new DataStore());
  }
View Full Code Here

Examples of krati.store.DataStore

            registration.unregister();
        }
    }

    public Producer createProducer() throws Exception {
        DataStore dataStore = null;
        KratiDataStoreRegistration registration = dataStoreRegistry.get(path);
        if (registration != null) {
            dataStore = registration.getDataStore();
        }
        if (dataStore == null || !dataStore.isOpen()) {
            dataStore = KratiHelper.createDataStore(path, initialCapacity, segmentFileSize, segmentFactory, hashFunction, keySerializer, valueSerializer);
            dataStoreRegistry.put(path, new KratiDataStoreRegistration(dataStore));
        }
        return new KratiProducer(this, dataStore);
    }
View Full Code Here

Examples of mil.nga.giat.geowave.store.DataStore

  @Override
  protected void generateGrid(
      final BasicAccumuloOperations bao ) {

    // create our datastore object
    final DataStore geowaveDataStore = getGeowaveDataStore(bao);

    // In order to store data we need to determine the type of data store
    final SimpleFeatureType point = createPointFeatureType();

    // This a factory class that builds simple feature objects based on the
    // type passed
    final SimpleFeatureBuilder pointBuilder = new SimpleFeatureBuilder(
        point);

    // This is an adapter, that is needed to describe how to persist the
    // data type passed
    final FeatureDataAdapter adapter = createDataAdapter(point);

    // This describes how to index the data
    final Index index = createSpatialIndex();

    // features require a featureID - this should be unqiue as it's a
    // foreign key on the feature
    // (i.e. sending in a new feature with the same feature id will
    // overwrite the existing feature)
    int featureId = 0;

    final Thread ingestThread = new Thread(
        new Runnable() {
          @Override
          public void run() {
            geowaveDataStore.ingest(
                adapter,
                index,
                features);
          }
        },
View Full Code Here

Examples of net.sf.uadetector.datastore.DataStore

    versionOut.close();
  }

  private static final DataStore determineDataStore(final String argument) {
    final boolean isOffline = argument != null && argument.toLowerCase().equals("offline");
    final DataStore fallback = new SimpleXmlDataStore(DATA_URL, VERSION_URL);
    return isOffline ? fallback : new OnlineXmlDataStore();
  }
View Full Code Here

Examples of net.sf.wicketdemo.service.DataStore

    final ListView<DataStore> lv = new ListView<DataStore>("dataStores", Arrays.asList(DataStore.values())) {
      private static final long serialVersionUID = 1L;
     
      @Override
      protected void populateItem(final ListItem<DataStore> item) {
        final DataStore ds = item.getModelObject();
       
        final DisplayMapPanel displayMapPanel = new DisplayMapPanel("dataStore");
        item.add(displayMapPanel);
        displayMapPanel.setTitle("DataStore[" + ds.toString() + "]:");
        displayMapPanel.setMap(ds.getDataMap());
      }
    };
    add(lv);
  }
View Full Code Here

Examples of org.activiti.bpmn.model.DataStore

    return "datastore.bpmn";
  }
 
  private void validateModel(BpmnModel model) {
    assertEquals(1, model.getDataStores().size());
    DataStore dataStore = model.getDataStore("DataStore_1");
    assertNotNull(dataStore);
    assertEquals("DataStore_1", dataStore.getId());
    assertEquals("test", dataStore.getDataState());
    assertEquals("Test Database", dataStore.getName());
    assertEquals("test", dataStore.getItemSubjectRef());
   
    FlowElement refElement = model.getFlowElement("DataStoreReference_1");
    assertNotNull(refElement);
    assertTrue(refElement instanceof DataStoreReference);
   
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.