Search in sources :

Example 1 with RDBDocumentNodeStoreBuilder

use of org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder in project jackrabbit-oak by apache.

the class DocumentNodeStoreService method registerNodeStore.

private void registerNodeStore() throws IOException {
    DocumentNodeStoreBuilder<?> mkBuilder;
    if (documentStoreType == DocumentStoreType.RDB) {
        RDBDocumentNodeStoreBuilder builder = newRDBDocumentNodeStoreBuilder();
        configureBuilder(builder);
        checkNotNull(dataSource, "DataStore type set [%s] but DataSource reference not initialized", PROP_DS_TYPE);
        if (!customBlobStore) {
            checkNotNull(blobDataSource, "DataStore type set [%s] but BlobDataSource reference not initialized", PROP_DS_TYPE);
            builder.setRDBConnection(dataSource, blobDataSource);
            log.info("Connected to datasources {} {}", dataSource, blobDataSource);
        } else {
            if (blobDataSource != null && blobDataSource != dataSource) {
                log.info("Ignoring blobDataSource {} as custom blob store takes precedence.", blobDataSource);
            }
            builder.setRDBConnection(dataSource);
            log.info("Connected to datasource {}", dataSource);
        }
        mkBuilder = builder;
    } else {
        String uri = config.mongouri();
        String db = config.db();
        boolean soKeepAlive = config.socketKeepAlive();
        MongoClientURI mongoURI = new MongoClientURI(uri);
        String persistentCache = resolvePath(config.persistentCache(), DEFAULT_PERSISTENT_CACHE);
        String journalCache = resolvePath(config.journalCache(), DEFAULT_JOURNAL_CACHE);
        if (log.isInfoEnabled()) {
            // Take care around not logging the uri directly as it
            // might contain passwords
            log.info("Starting DocumentNodeStore with host={}, db={}, cache size (MB)={}, persistentCache={}, " + "journalCache={}, blobCacheSize (MB)={}, maxReplicationLagInSecs={}", mongoURI.getHosts(), db, config.cache(), persistentCache, journalCache, config.blobCacheSize(), config.maxReplicationLagInSecs());
            log.info("Mongo Connection details {}", MongoConnection.toString(mongoURI.getOptions()));
        }
        MongoDocumentNodeStoreBuilder builder = newMongoDocumentNodeStoreBuilder();
        configureBuilder(builder);
        builder.setMaxReplicationLag(config.maxReplicationLagInSecs(), TimeUnit.SECONDS);
        builder.setSocketKeepAlive(soKeepAlive);
        builder.setMongoDB(uri, db, config.blobCacheSize());
        mkBuilder = builder;
        log.info("Connected to database '{}'", db);
    }
    if (!customBlobStore) {
        defaultBlobStore = mkBuilder.getBlobStore();
        log.info("Registering the BlobStore with ServiceRegistry");
        blobStoreReg = context.getBundleContext().registerService(BlobStore.class.getName(), defaultBlobStore, null);
    }
    // Set wrapping blob store after setting the DB
    if (isWrappingCustomBlobStore()) {
        ((BlobStoreWrapper) blobStore).setBlobStore(mkBuilder.getBlobStore());
        mkBuilder.setBlobStore(blobStore);
    }
    // attach GCMonitor
    final GCMonitorTracker gcMonitor = new GCMonitorTracker();
    gcMonitor.start(whiteboard);
    closer.register(asCloseable(gcMonitor));
    Logger vgcLogger = LoggerFactory.getLogger(VersionGarbageCollector.class);
    GCMonitor loggingGCMonitor;
    if (isContinuousRevisionGC()) {
        // log less chatty with continuous RevisionGC
        loggingGCMonitor = new QuietGCMonitor(vgcLogger);
    } else {
        loggingGCMonitor = new LoggingGCMonitor(vgcLogger);
    }
    mkBuilder.setGCMonitor(new DelegatingGCMonitor(newArrayList(gcMonitor, loggingGCMonitor)));
    nodeStore = mkBuilder.build();
    // ensure a clusterId is initialized
    // and expose it as 'oak.clusterid' repository descriptor
    GenericDescriptors clusterIdDesc = new GenericDescriptors();
    clusterIdDesc.put(ClusterRepositoryInfo.OAK_CLUSTERID_REPOSITORY_DESCRIPTOR_KEY, new SimpleValueFactory().createValue(ClusterRepositoryInfo.getOrCreateId(nodeStore)), true, false);
    whiteboard.register(Descriptors.class, clusterIdDesc, Collections.emptyMap());
    // If a shared data store register the repo id in the data store
    if (SharedDataStoreUtils.isShared(blobStore)) {
        String repoId = null;
        try {
            repoId = ClusterRepositoryInfo.getOrCreateId(nodeStore);
            ((SharedDataStore) blobStore).addMetadataRecord(new ByteArrayInputStream(new byte[0]), SharedDataStoreUtils.SharedStoreRecordType.REPOSITORY.getNameFromId(repoId));
        } catch (Exception e) {
            throw new IOException("Could not register a unique repositoryId", e);
        }
        if (blobStore instanceof BlobTrackingStore) {
            BlobTrackingStore trackingStore = (BlobTrackingStore) blobStore;
            if (trackingStore.getTracker() != null) {
                trackingStore.getTracker().close();
            }
            ((BlobTrackingStore) blobStore).addTracker(new BlobIdTracker(getRepositoryHome(), repoId, config.blobTrackSnapshotIntervalInSecs(), (SharedDataStore) blobStore));
        }
    }
    registerJMXBeans(nodeStore, mkBuilder);
    registerLastRevRecoveryJob(nodeStore);
    registerJournalGC(nodeStore);
    registerVersionGCJob(nodeStore);
    registerDocumentStoreMetrics(mkBuilder.getDocumentStore());
    if (!isNodeStoreProvider()) {
        observerTracker = new ObserverTracker(nodeStore);
        observerTracker.start(context.getBundleContext());
    }
    journalPropertyHandlerFactory.start(whiteboard);
    DocumentStore ds = nodeStore.getDocumentStore();
    // OAK-2682: time difference detection applied at startup with a default
    // max time diff of 2000 millis (2sec)
    final long maxDiff = Long.parseLong(System.getProperty("oak.documentMK.maxServerTimeDiffMillis", "2000"));
    try {
        if (maxDiff >= 0) {
            final long timeDiff = ds.determineServerTimeDifferenceMillis();
            log.info("registerNodeStore: server time difference: {}ms (max allowed: {}ms)", timeDiff, maxDiff);
            if (Math.abs(timeDiff) > maxDiff) {
                throw new AssertionError("Server clock seems off (" + timeDiff + "ms) by more than configured amount (" + maxDiff + "ms)");
            }
        }
    } catch (RuntimeException e) {
        // no checked exception
        // in case of a RuntimeException, just log but continue
        log.warn("registerNodeStore: got RuntimeException while trying to determine time difference to server: " + e, e);
    }
    String[] serviceClasses;
    if (isNodeStoreProvider()) {
        registerNodeStoreProvider(nodeStore);
        serviceClasses = new String[] { DocumentNodeStore.class.getName(), Clusterable.class.getName() };
    } else {
        serviceClasses = new String[] { NodeStore.class.getName(), DocumentNodeStore.class.getName(), Clusterable.class.getName() };
    }
    Dictionary<String, Object> props = new Hashtable<String, Object>();
    props.put(Constants.SERVICE_PID, DocumentNodeStore.class.getName());
    props.put(DESCRIPTION, getMetadata(ds));
    // OAK-2844: in order to allow DocumentDiscoveryLiteService to directly
    // require a service DocumentNodeStore (instead of having to do an 'instanceof')
    // the registration is now done for both NodeStore and DocumentNodeStore here.
    nodeStoreReg = context.getBundleContext().registerService(serviceClasses, nodeStore, props);
}
Also used : ObserverTracker(org.apache.jackrabbit.oak.spi.commit.ObserverTracker) MongoClientURI(com.mongodb.MongoClientURI) DelegatingGCMonitor(org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor) Logger(org.slf4j.Logger) GCMonitor(org.apache.jackrabbit.oak.spi.gc.GCMonitor) DelegatingGCMonitor(org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor) LoggingGCMonitor(org.apache.jackrabbit.oak.spi.gc.LoggingGCMonitor) Clusterable(org.apache.jackrabbit.oak.spi.state.Clusterable) MongoDocumentStore(org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore) NodeStore(org.apache.jackrabbit.oak.spi.state.NodeStore) BlobTrackingStore(org.apache.jackrabbit.oak.plugins.blob.BlobTrackingStore) LoggingGCMonitor(org.apache.jackrabbit.oak.spi.gc.LoggingGCMonitor) SharedDataStore(org.apache.jackrabbit.oak.plugins.blob.SharedDataStore) GCMonitorTracker(org.apache.jackrabbit.oak.spi.gc.GCMonitorTracker) GenericDescriptors(org.apache.jackrabbit.oak.spi.descriptors.GenericDescriptors) Hashtable(java.util.Hashtable) IOException(java.io.IOException) SimpleValueFactory(org.apache.jackrabbit.commons.SimpleValueFactory) IOException(java.io.IOException) ParseException(java.text.ParseException) BundleException(org.osgi.framework.BundleException) UncheckedExecutionException(com.google.common.util.concurrent.UncheckedExecutionException) MongoDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentNodeStoreBuilder) MongoDocumentNodeStoreBuilder.newMongoDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentNodeStoreBuilder.newMongoDocumentNodeStoreBuilder) BlobIdTracker(org.apache.jackrabbit.oak.plugins.blob.datastore.BlobIdTracker) ByteArrayInputStream(java.io.ByteArrayInputStream) RDBDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder) RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder) BlobStoreWrapper(org.apache.jackrabbit.oak.spi.blob.BlobStoreWrapper)

Example 2 with RDBDocumentNodeStoreBuilder

use of org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder in project jackrabbit-oak by apache.

the class JdbcFactory method create.

@Override
public NodeStore create(BlobStore blobStore, Closer closer) throws IOException {
    System.setProperty(DocumentNodeStore.SYS_PROP_DISABLE_JOURNAL, "true");
    RDBDocumentNodeStoreBuilder builder = baseConfiguration(newRDBDocumentNodeStoreBuilder(), cacheSize);
    if (blobStore != null) {
        builder.setBlobStore(blobStore);
    }
    builder.setRDBConnection(getDataSource(closer));
    if (readOnly) {
        builder.setReadOnlyMode();
    }
    log.info("Initialized DocumentNodeStore on RDB with Cache size : {} MB, Fast migration : {}", cacheSize, builder.isDisableBranches());
    DocumentNodeStore documentNodeStore = builder.build();
    // TODO probably we should disable all observers, see OAK-5651
    documentNodeStore.getBundlingConfigHandler().unregisterObserver();
    closer.register(documentNodeStore::dispose);
    return documentNodeStore;
}
Also used : RDBDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder) RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder(org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder) DocumentNodeStore(org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore)

Aggregations

RDBDocumentNodeStoreBuilder (org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder)2 RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder (org.apache.jackrabbit.oak.plugins.document.rdb.RDBDocumentNodeStoreBuilder.newRDBDocumentNodeStoreBuilder)2 UncheckedExecutionException (com.google.common.util.concurrent.UncheckedExecutionException)1 MongoClientURI (com.mongodb.MongoClientURI)1 ByteArrayInputStream (java.io.ByteArrayInputStream)1 IOException (java.io.IOException)1 ParseException (java.text.ParseException)1 Hashtable (java.util.Hashtable)1 SimpleValueFactory (org.apache.jackrabbit.commons.SimpleValueFactory)1 BlobTrackingStore (org.apache.jackrabbit.oak.plugins.blob.BlobTrackingStore)1 SharedDataStore (org.apache.jackrabbit.oak.plugins.blob.SharedDataStore)1 BlobIdTracker (org.apache.jackrabbit.oak.plugins.blob.datastore.BlobIdTracker)1 DocumentNodeStore (org.apache.jackrabbit.oak.plugins.document.DocumentNodeStore)1 MongoDocumentNodeStoreBuilder (org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentNodeStoreBuilder)1 MongoDocumentNodeStoreBuilder.newMongoDocumentNodeStoreBuilder (org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentNodeStoreBuilder.newMongoDocumentNodeStoreBuilder)1 MongoDocumentStore (org.apache.jackrabbit.oak.plugins.document.mongo.MongoDocumentStore)1 BlobStoreWrapper (org.apache.jackrabbit.oak.spi.blob.BlobStoreWrapper)1 ObserverTracker (org.apache.jackrabbit.oak.spi.commit.ObserverTracker)1 GenericDescriptors (org.apache.jackrabbit.oak.spi.descriptors.GenericDescriptors)1 DelegatingGCMonitor (org.apache.jackrabbit.oak.spi.gc.DelegatingGCMonitor)1