Return-Path: X-Original-To: apmail-zest-commits-archive@minotaur.apache.org Delivered-To: apmail-zest-commits-archive@minotaur.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id E4734175C2 for ; Sun, 19 Jul 2015 16:40:27 +0000 (UTC) Received: (qmail 65838 invoked by uid 500); 19 Jul 2015 16:40:27 -0000 Delivered-To: apmail-zest-commits-archive@zest.apache.org Received: (qmail 65787 invoked by uid 500); 19 Jul 2015 16:40:27 -0000 Mailing-List: contact commits-help@zest.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@zest.apache.org Delivered-To: mailing list commits@zest.apache.org Received: (qmail 65741 invoked by uid 99); 19 Jul 2015 16:40:27 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Sun, 19 Jul 2015 16:40:27 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 9524FE0260; Sun, 19 Jul 2015 16:40:27 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 8bit From: paulmerlin@apache.org To: commits@zest.apache.org Date: Sun, 19 Jul 2015 16:40:27 -0000 Message-Id: <4a83714c50534cd9a541799ae59f2cfa@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [1/6] zest-qi4j git commit: ZEST-104 Remove Voldemort EntityStore Repository: zest-qi4j Updated Branches: refs/heads/develop 2daf2be41 -> 3a2f6c948 ZEST-104 Remove Voldemort EntityStore Project: http://git-wip-us.apache.org/repos/asf/zest-qi4j/repo Commit: http://git-wip-us.apache.org/repos/asf/zest-qi4j/commit/294aa1d2 Tree: http://git-wip-us.apache.org/repos/asf/zest-qi4j/tree/294aa1d2 Diff: http://git-wip-us.apache.org/repos/asf/zest-qi4j/diff/294aa1d2 Branch: refs/heads/develop Commit: 294aa1d2b9fb7197f26886a9daad177ec035f1a9 Parents: 2daf2be Author: Paul Merlin Authored: Sat Jul 18 16:43:08 2015 +0200 Committer: Paul Merlin Committed: Sat Jul 18 17:31:31 2015 +0200 ---------------------------------------------------------------------- extensions/entitystore-voldemort/build.gradle | 46 --- extensions/entitystore-voldemort/dev-status.xml | 35 -- .../src/docs/es-voldemort.txt | 50 --- .../voldemort/VoldemortConfiguration.java | 147 -------- .../voldemort/VoldemortEntityStoreMixin.java | 344 ------------------- .../voldemort/VoldemortEntityStoreService.java | 50 --- .../voldemort/assembly/VoldemortAssembler.java | 48 --- .../entitystore/voldemort/assembly/package.html | 21 -- .../org/qi4j/entitystore/voldemort/package.html | 21 -- .../entitystore/voldemort/VoldemortTest.java | 129 ------- .../org/qi4j/entitystore/voldemort/cluster.xml | 38 -- .../qi4j/entitystore/voldemort/node0.properties | 207 ----------- .../qi4j/entitystore/voldemort/node1.properties | 207 ----------- .../org/qi4j/entitystore/voldemort/stores.xml | 37 -- libraries.gradle | 14 - manual/src/docs/userguide/extensions.txt | 4 - settings.gradle | 1 - 17 files changed, 1399 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/build.gradle ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/build.gradle b/extensions/entitystore-voldemort/build.gradle deleted file mode 100644 index 385bd62..0000000 --- a/extensions/entitystore-voldemort/build.gradle +++ /dev/null @@ -1,46 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. - */ - -description = "Apache Zest™ Voldemort EntityStore Extension" - -jar { manifest { name = "Apache Zest™ Extension - EntityStore - Voldemort" }} - -dependencies { - - compile project(":org.qi4j.core:org.qi4j.core.bootstrap") - compile project(":org.qi4j.libraries:org.qi4j.library.locking") - compile libraries.voldemort - compile libraries.guava - - testCompile project(":org.qi4j.core:org.qi4j.core.testsupport") - testCompile(project(":org.qi4j.extensions:org.qi4j.extension.valueserialization-orgjson")) - - testRuntime project(":org.qi4j.core:org.qi4j.core.runtime") - testRuntime libraries.logback - testRuntime libraries.sleepycat - testRuntime libraries.log4j - testRuntime libraries.jdom - testRuntime libraries.velocity - testRuntime libraries.commons_codec - testRuntime libraries.commons_dbcp - testRuntime libraries.commons_io - testRuntime libraries.commons_lang - -} - http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/dev-status.xml ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/dev-status.xml b/extensions/entitystore-voldemort/dev-status.xml deleted file mode 100644 index 169068f..0000000 --- a/extensions/entitystore-voldemort/dev-status.xml +++ /dev/null @@ -1,35 +0,0 @@ - - - - - - beta - - - good - - - good - - - ALv2 - - http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/docs/es-voldemort.txt ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/docs/es-voldemort.txt b/extensions/entitystore-voldemort/src/docs/es-voldemort.txt deleted file mode 100644 index 9d6d7b3..0000000 --- a/extensions/entitystore-voldemort/src/docs/es-voldemort.txt +++ /dev/null @@ -1,50 +0,0 @@ -/////////////////////////////////////////////////////////////// - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, - * software distributed under the License is distributed on an - * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY - * KIND, either express or implied. See the License for the - * specific language governing permissions and limitations - * under the License. -/////////////////////////////////////////////////////////////// - -[[extension-es-voldemort, Voldemort EntityStore]] -= Voldemort EntityStore = - -[devstatus] --------------- -source=extensions/entitystore-voldemort/dev-status.xml --------------- - -EntityStore service backed by http://www.project-voldemort.com/voldemort/[Voldemort]. - -include::../../build/docs/buildinfo/artifact.txt[] - -== Assembly == - -Assembly is done using the provided Assembler. - -[snippet,java] ----- -source=extensions/entitystore-voldemort/src/test/java/org/qi4j/entitystore/voldemort/VoldemortTest.java -tag=assembly ----- - -== Configuration == - -Most of the configuration of Voldemort is available in the Zest™ Configuration Entity. - -[snippet,java] ----- -source=extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortConfiguration.java -tag=config ----- http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortConfiguration.java ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortConfiguration.java b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortConfiguration.java deleted file mode 100644 index a59b342..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortConfiguration.java +++ /dev/null @@ -1,147 +0,0 @@ -/* - * Copyright (c) 2010 Niclas Hedhman . - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or - * implied. - * - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package org.qi4j.entitystore.voldemort; - -import java.util.List; -import org.qi4j.api.common.Optional; -import org.qi4j.api.configuration.ConfigurationComposite; -import org.qi4j.api.property.Property; - -/** - * The configuration entity for the Voldemort EntityStore. - *

- * Most of these properties are used to call the corresponding setters in the - * {@code voldemort.client.ClientConfig} object passed to Voldemort runtime upon start. - * The {@code voldemort.client.ClientConfig} is instantiated by the default constructor. - * - *

- */ -public interface VoldemortConfiguration extends ConfigurationComposite -{ - // START SNIPPET: config - @Optional - Property storeName(); - - // END SNIPPET: config - // @Optional -// Property clientZoneId(); -// - // START SNIPPET: config - @Optional - Property connectionTimeout(); - - /** - * The Bootstrap URL for Voldemort runtime to use. - *

- * The configuration property is optional. Default: "tcp://localhost:8581" - *

- *

- * This value is used to call voldemort.client.ClientConfig#setBootstrapUrls(java.util.List) - *

- * - * @return The property containing the bootstrap URL configuration. - */ - @Optional - Property> bootstrapUrl(); - - @Optional - Property enableJmx(); - - // END SNIPPET: config -// @Optional -// Property enablePipelineRoutedStore(); - - // START SNIPPET: config - @Optional - Property failureDetectorAsyncRecoveryInterval(); - - @Optional - Property failureDetectorBannagePeriod(); - - @Optional - Property> failureDetectorCatastrophicErrorType(); - - @Optional - Property failureDetectorImplementation(); - - @Optional - Property failureDetectoreRequestLengthThreshold(); - - @Optional - Property failureDetectorThreshold(); - - @Optional - Property failureDetectorThresholdCountMinimum(); - - @Optional - Property failureDetectorThreasholdInterval(); - - @Optional - Property maxBootstrapRetries(); - - @Optional - Property setMaxConnectionsPerNode(); - - @Optional - Property maxQueueRequests(); - - @Optional - Property maxThreads(); - - @Optional - Property maxTotalConnections(); - - /** Voldemort has avolved the format over time, and this property sets which request format to use. - * See {@code voldemort.client.protocol.RequestFormatType} in Voldemort for further details. - * - * @return The configuration property that contains the request type formet used in Voldemort. - */ - @Optional - Property requestFormatType(); - - /** Sets the routing tier of this Voldemort runtime. - *

- * Possible values are 'client' and 'server'. See {@code voldemort.client.RoutingTier} in - * Voldemort for details. - *

- * @return the confirguration property that contains the Routing Tier setting for Voldemort. - */ - @Optional - Property routingTier(); - - @Optional - Property routingTimeout(); - - // END SNIPPET: config -// @Optional -// Property selectors(); - - // START SNIPPET: config - @Optional - Property socketBufferSize(); - - @Optional - Property socketKeepAlive(); - - @Optional - Property socketTimeout(); - - @Optional - Property threadIdleTime(); -} http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreMixin.java ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreMixin.java b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreMixin.java deleted file mode 100644 index b11d161..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreMixin.java +++ /dev/null @@ -1,344 +0,0 @@ -/* Copyright 2010 Niclas Hedhman. - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or - * implied. - * - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package org.qi4j.entitystore.voldemort; - -import java.io.*; -import java.util.ConcurrentModificationException; -import java.util.List; -import java.util.concurrent.TimeUnit; -import java.util.concurrent.locks.ReadWriteLock; -import org.qi4j.api.configuration.Configuration; -import org.qi4j.api.entity.EntityDescriptor; -import org.qi4j.api.entity.EntityReference; -import org.qi4j.api.injection.scope.This; -import org.qi4j.api.service.ServiceActivation; -import org.qi4j.io.Input; -import org.qi4j.io.Output; -import org.qi4j.spi.entitystore.EntityNotFoundException; -import org.qi4j.spi.entitystore.EntityStoreException; -import org.qi4j.spi.entitystore.helpers.MapEntityStore; -import voldemort.client.*; -import voldemort.client.protocol.RequestFormatType; -import voldemort.versioning.ObsoleteVersionException; -import voldemort.versioning.Versioned; - -/** - * JDBM implementation of SerializationStore - */ -public class VoldemortEntityStoreMixin - implements ServiceActivation, MapEntityStore -{ - @This - private ReadWriteLock lock; - - @This - private Configuration config; - - private StoreClient client; - private StoreClientFactory factory; - - @Override - public void activateService() - throws Exception - { - VoldemortConfiguration conf = config.get(); - ClientConfig config = new ClientConfig(); - { - List value = conf.bootstrapUrl().get(); - if (value != null) - { - config.setBootstrapUrls(value); - } else - { - config.setBootstrapUrls("tcp://localhost:8581"); - } - } - { - Integer connectionTimeout = conf.connectionTimeout().get(); - if (connectionTimeout != null) - { - config.setConnectionTimeout(connectionTimeout, TimeUnit.MILLISECONDS); - } - } - { - Boolean enable = conf.enableJmx().get(); - if (enable != null) - { - config.setEnableJmx(enable); - } - } - { - Long recoveryInterval = conf.failureDetectorAsyncRecoveryInterval().get(); - if (recoveryInterval != null) - { - config.setFailureDetectorAsyncRecoveryInterval(recoveryInterval); - } - } - { - Long bannagePeriod = conf.failureDetectorBannagePeriod().get(); - if (bannagePeriod != null) - { - config.setFailureDetectorBannagePeriod(bannagePeriod); - } - } - { - List failureDetectorCatastrophicErrorTypes = conf.failureDetectorCatastrophicErrorType().get(); - if (failureDetectorCatastrophicErrorTypes != null) - { - config.setFailureDetectorCatastrophicErrorTypes(failureDetectorCatastrophicErrorTypes); - } - } - { - String failureDetectorImplementation = conf.failureDetectorImplementation().get(); - if (failureDetectorImplementation != null) - { - config.setFailureDetectorImplementation(failureDetectorImplementation); - } - } - { - Long failureDetectorRequestLengthThreshold = conf.failureDetectoreRequestLengthThreshold().get(); - if (failureDetectorRequestLengthThreshold != null) - { - config.setFailureDetectorRequestLengthThreshold(failureDetectorRequestLengthThreshold); - } - } - { - Integer failureDetectorThreshold = conf.failureDetectorThreshold().get(); - if (failureDetectorThreshold != null) - { - config.setFailureDetectorThreshold(failureDetectorThreshold); - } - } - { - Integer detectorThresholdCountMinimum = conf.failureDetectorThresholdCountMinimum().get(); - if (detectorThresholdCountMinimum != null) - { - config.setFailureDetectorThresholdCountMinimum(detectorThresholdCountMinimum); - } - } - { - Long failureDetectorThresholdInterval = conf.failureDetectorThreasholdInterval().get(); - if (failureDetectorThresholdInterval != null) - { - config.setFailureDetectorThresholdInterval(failureDetectorThresholdInterval); - } - } - { - Integer maxBootstrapRetries = conf.maxBootstrapRetries().get(); - if (maxBootstrapRetries != null) - { - config.setMaxBootstrapRetries(maxBootstrapRetries); - } - } - { - Integer maxConnectionsPerNode = conf.setMaxConnectionsPerNode().get(); - if (maxConnectionsPerNode != null) - { - config.setMaxConnectionsPerNode(maxConnectionsPerNode); - } - } - { - Integer maxQueueRequests = conf.maxQueueRequests().get(); - if (maxQueueRequests != null) - { - config.setMaxQueuedRequests(maxQueueRequests); - } - } - { - Integer maxThreads = conf.maxThreads().get(); - if (maxThreads != null) - { - config.setMaxThreads(maxThreads); - } - } - { - Integer maxTotalConnections = conf.maxTotalConnections().get(); - if (maxTotalConnections != null) - { - config.setMaxTotalConnections(maxTotalConnections); - } - } - { - String formatTypeCode = conf.requestFormatType().get(); - if (formatTypeCode != null) - { - RequestFormatType formatType = RequestFormatType.fromCode(formatTypeCode); - config.setRequestFormatType(formatType); - } - } - { - String routingTierString = conf.routingTier().get(); - if (routingTierString != null) - { - RoutingTier routingTier = RoutingTier.fromDisplay(routingTierString); - config.setRoutingTier(routingTier); - } - } - { - Integer routingTimeout = conf.routingTimeout().get(); - if (routingTimeout != null) - { - config.setRoutingTimeout(routingTimeout, TimeUnit.MILLISECONDS); - } - } - { - Integer bufferSize = conf.socketBufferSize().get(); - if (bufferSize != null) - { - config.setSocketBufferSize(bufferSize); - } - } - { - Boolean socketKeepAlive = conf.socketKeepAlive().get(); - if (socketKeepAlive != null) - { - config.setSocketKeepAlive(socketKeepAlive); - } - } - { - Integer socketTimeout = conf.socketTimeout().get(); - if (socketTimeout != null) - { - config.setSocketTimeout(socketTimeout, TimeUnit.MILLISECONDS); - } - } - { - Integer idleTime = conf.threadIdleTime().get(); - if (idleTime != null) - { - config.setThreadIdleTime(idleTime, TimeUnit.MILLISECONDS); - } - } - factory = new SocketStoreClientFactory(config); - // create a client that executes operations on a single store - String storeName = conf.storeName().get(); - if (storeName == null) - storeName = "qi4j-entities"; - client = factory.getStoreClient(storeName); - - } - - @Override - public void passivateService() - throws Exception - { - factory.close(); - } - - @Override - public Reader get(EntityReference entityReference) - throws EntityStoreException - { - try - { - Versioned versioned = client.get(entityReference.identity()); - if (versioned == null) - { - throw new EntityNotFoundException(entityReference); - } - byte[] serializedState = versioned.getValue(); - return new StringReader(new String(serializedState, "UTF-8")); - } catch (IOException e) - { - throw new EntityStoreException(e); - } - } - - @Override - public void applyChanges(MapChanges changes) - throws IOException - { - try - { - changes.visitMap(new MapChanger() - { - @Override - public Writer newEntity(final EntityReference ref, EntityDescriptor descriptor ) - throws IOException - { - return new StringWriter(1000) - { - @Override - public void close() - throws IOException - { - super.close(); - byte[] stateArray = toString().getBytes("UTF-8"); - client.put(ref.identity(), stateArray); - } - }; - } - - @Override - public Writer updateEntity(final EntityReference ref, EntityDescriptor descriptor) - throws IOException - { - return new StringWriter(1000) - { - @Override - public void close() - throws IOException - { - super.close(); - byte[] stateArray = toString().getBytes("UTF-8"); - try - { - client.put(ref.identity(), stateArray); - } catch (ObsoleteVersionException e) - { - throw new ConcurrentModificationException( - "Concurrent modification attempted for " + ref.identity()); - } - } - }; - } - - @Override - public void removeEntity(EntityReference ref, EntityDescriptor descriptor) - throws EntityNotFoundException - { - client.delete(ref.identity()); - } - }); - } catch (Exception e) - { - if (e instanceof IOException) - { - throw (IOException) e; - } else if (e instanceof EntityStoreException) - { - throw (EntityStoreException) e; - } else - { - throw new IOException( e ); - } - } - } - - @Override - public Input entityStates() - { - return new Input() - { - @Override - public void transferTo(Output receiverThrowableTypeOutput) throws IOException, ReceiverThrowableType - { - // TODO: Can't get hold of all entities, unless storing all the keys separately, which is enormously expensive - } - }; - } -} \ No newline at end of file http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreService.java ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreService.java b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreService.java deleted file mode 100644 index fcaff41..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/VoldemortEntityStoreService.java +++ /dev/null @@ -1,50 +0,0 @@ -/* Copyright 2010 Niclas Hedhman. - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or - * implied. - * - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package org.qi4j.entitystore.voldemort; - -import org.qi4j.api.concern.Concerns; -import org.qi4j.api.configuration.Configuration; -import org.qi4j.api.mixin.Mixins; -import org.qi4j.api.service.ServiceActivation; -import org.qi4j.api.service.ServiceComposite; -import org.qi4j.library.locking.LockingAbstractComposite; -import org.qi4j.spi.entitystore.ConcurrentModificationCheckConcern; -import org.qi4j.spi.entitystore.EntityStateVersions; -import org.qi4j.spi.entitystore.EntityStore; -import org.qi4j.spi.entitystore.StateChangeNotificationConcern; -import org.qi4j.spi.entitystore.helpers.JSONMapEntityStoreActivation; -import org.qi4j.spi.entitystore.helpers.JSONMapEntityStoreMixin; -import org.qi4j.spi.entitystore.helpers.StateStore; - -/** - * EntityStore service backed by Voldemort. - */ - -@Concerns( { StateChangeNotificationConcern.class, ConcurrentModificationCheckConcern.class } ) -@Mixins( { JSONMapEntityStoreMixin.class, VoldemortEntityStoreMixin.class } ) -public interface VoldemortEntityStoreService - extends EntityStore, - EntityStateVersions, - StateStore, - ServiceComposite, - ServiceActivation, - JSONMapEntityStoreActivation, - LockingAbstractComposite, - Configuration - -{ -} http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/VoldemortAssembler.java ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/VoldemortAssembler.java b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/VoldemortAssembler.java deleted file mode 100644 index 9efff11..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/VoldemortAssembler.java +++ /dev/null @@ -1,48 +0,0 @@ -/* - * Copyright (c) 2010 Niclas Hedhman . - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or - * implied. - * - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package org.qi4j.entitystore.voldemort.assembly; - -import org.qi4j.bootstrap.Assemblers; -import org.qi4j.bootstrap.AssemblyException; -import org.qi4j.bootstrap.ModuleAssembly; -import org.qi4j.bootstrap.ServiceDeclaration; -import org.qi4j.entitystore.voldemort.VoldemortConfiguration; -import org.qi4j.entitystore.voldemort.VoldemortEntityStoreService; -import org.qi4j.spi.uuid.UuidIdentityGeneratorService; - -public class VoldemortAssembler - extends Assemblers.VisibilityIdentityConfig -{ - @Override - public void assemble( ModuleAssembly module ) - throws AssemblyException - { - module.services( UuidIdentityGeneratorService.class ).visibleIn( visibility() ); - ServiceDeclaration service = module.services( VoldemortEntityStoreService.class ). - visibleIn( visibility() ). - instantiateOnStartup(); - if( hasIdentity() ) - { - service.identifiedBy( identity() ); - } - if( hasConfig() ) - { - configModule().entities( VoldemortConfiguration.class ).visibleIn( configVisibility() ); - } - } -} http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/package.html ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/package.html b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/package.html deleted file mode 100644 index 6c76d75..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/assembly/package.html +++ /dev/null @@ -1,21 +0,0 @@ - - - -

Voldemort EntityStore Assembly.

- - \ No newline at end of file http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/package.html ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/package.html b/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/package.html deleted file mode 100644 index dd1a0b1..0000000 --- a/extensions/entitystore-voldemort/src/main/java/org/qi4j/entitystore/voldemort/package.html +++ /dev/null @@ -1,21 +0,0 @@ - - - -

Voldemort EntityStore.

- - \ No newline at end of file http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/test/java/org/qi4j/entitystore/voldemort/VoldemortTest.java ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/test/java/org/qi4j/entitystore/voldemort/VoldemortTest.java b/extensions/entitystore-voldemort/src/test/java/org/qi4j/entitystore/voldemort/VoldemortTest.java deleted file mode 100644 index 05eaa6b..0000000 --- a/extensions/entitystore-voldemort/src/test/java/org/qi4j/entitystore/voldemort/VoldemortTest.java +++ /dev/null @@ -1,129 +0,0 @@ -/* - * Copyright (c) 2010 Niclas Hedhman . - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or - * implied. - * - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package org.qi4j.entitystore.voldemort; - -import org.junit.Ignore; -import org.qi4j.api.common.Visibility; -import org.qi4j.bootstrap.AssemblyException; -import org.qi4j.bootstrap.ModuleAssembly; -import org.qi4j.entitystore.voldemort.assembly.VoldemortAssembler; -import org.qi4j.test.entity.AbstractEntityStoreTest; -import voldemort.server.VoldemortConfig; -import voldemort.server.VoldemortServer; - -import java.io.*; -import java.util.ArrayList; -import java.util.List; -import java.util.Properties; -import java.util.Random; -import org.qi4j.test.EntityTestAssembler; -import org.qi4j.valueserialization.orgjson.OrgJsonValueSerializationAssembler; - -@Ignore( "This version of Voldemort is still using Jetty 6. If we can not upgrade, we should drop support for this ES." ) -public class VoldemortTest - extends AbstractEntityStoreTest -{ - - private List servers = new ArrayList(); - - @Override - public void setUp() - throws Exception - { - Thread.sleep( 200 ); - File voldemortHome1 = setupVoldemortHome(); - startServer( voldemortHome1, "node0.properties" ); - File voldemortHome2 = setupVoldemortHome(); - startServer( voldemortHome2, "node1.properties" ); - super.setUp(); - } - - @Override - public void tearDown() - throws Exception - { - super.tearDown(); - for( VoldemortServer server : servers ) - { - server.stop(); - } - } - - // START SNIPPET: assembly - @Override - public void assemble( ModuleAssembly module ) - throws AssemblyException - { - // END SNIPPET: assembly - super.assemble( module ); - ModuleAssembly config = module.layer().module( "config" ); - new EntityTestAssembler().assemble( config ); - new OrgJsonValueSerializationAssembler().assemble( module ); - - // START SNIPPET: assembly - new VoldemortAssembler(). - visibleIn( Visibility.layer ). - withConfig( config, Visibility.layer ). - assemble( module ); - // END SNIPPET: assembly - } - - private File setupVoldemortHome() - throws IOException - { - File tmp = File.createTempFile( "qi4j", "" ); - File dir = tmp.getParentFile(); - File voldemortHome = new File( dir, "qi4j-voldemort" + new Random().nextInt( 10000 ) ); - boolean created = voldemortHome.mkdir(); - File configDir = new File( voldemortHome, "config" ); - created = configDir.mkdir(); - copyFile( "cluster.xml", configDir ); - copyFile( "stores.xml", configDir ); - return voldemortHome; - } - - private void startServer( File voldemortHome, String serverProps ) - throws IOException - { - Properties props = new Properties(); - InputStream in = getClass().getResourceAsStream( serverProps ); - props.load( in ); - props.setProperty( "voldemort.home", voldemortHome.getCanonicalPath() ); - VoldemortConfig config = new VoldemortConfig( props ); - config.setEnableJmx( false ); - VoldemortServer server = new VoldemortServer( config ); - server.start(); - this.servers.add( server ); - } - - private void copyFile( String source, File voldemortHome ) - throws IOException - { - InputStream in = getClass().getResourceAsStream( source ); - FileOutputStream out = new FileOutputStream( new File( voldemortHome, source ) ); - BufferedOutputStream stream = new BufferedOutputStream( out ); - int data = in.read(); - while( data != -1 ) - { - stream.write( data ); - data = in.read(); - } - in.close(); - stream.close(); - } -} http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/cluster.xml ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/cluster.xml b/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/cluster.xml deleted file mode 100644 index cafc886..0000000 --- a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/cluster.xml +++ /dev/null @@ -1,38 +0,0 @@ - - - - - qi4j-test-cluster - - - 0 - localhost - 8481 - 8581 - - 0,1,2,3 - - - 1 - localhost - 8681 - 8781 - 4,5,6,7 - - \ No newline at end of file http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node0.properties ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node0.properties b/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node0.properties deleted file mode 100644 index f2b3a3b..0000000 --- a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node0.properties +++ /dev/null @@ -1,207 +0,0 @@ -# -# Copyright (c) 2010 Niclas Hedhman . -# -# Licensed under the Apache License, Version 2.0 (the "License"); -# you may not use this file except in compliance with the License. -# You may obtain a copy of the License at -# -# http://www.apache.org/licenses/LICENSE-2.0 -# -# Unless required by applicable law or agreed to in writing, software -# distributed under the License is distributed on an "AS IS" BASIS, -# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or -# implied. -# -# See the License for the specific language governing permissions and -# limitations under the License. -# - -# The unique, sequential identifier for this server in the cluster (starts with 0) -# default: none, must be specfified -node.id=0 - -# The base directory for voldemort. Can also be specified via the environment variable VOLDEMORT_HOME or -# via a command line option. -# default: none -# voldemort.home= - -# The directory where voldemort data is stored -# default: ${voldemort.home}/data -# data.directory= - - -# The directory where voldemort configuration is stored -# default: ${voldemort.home}/config -# metadata.directory= - -# Should the BDB engine be enabled? -# default: true -# enable.bdb.engine= - - -# The BDB cache that is shared by all BDB tables. Bigger is better. -# default: 200MB (make it bigger!!!) -bdb.cache.size=50000000 - - -# Should transactions be immediately written to disk? -# default: false -# bdb.write.transactions= - -# When the transaction has been written to disk should we force the disk to flush the OS cache. This is a fairly expensive operation. -# default: false -# bdb.flush.transactions= - - -# The directory where the BDB environment is located -# default: ${data.directory}/bdb -# bdb.data.directory= - - -# The size of an individual log file -# default: 1GB -# bdb.max.logfile.size= - - -# The fanout size for the btree. Bigger fanout more effienciently supports larger btrees. -# default: 512 -# bdb.btree.fanout= - - -# How often (in bytes) should we checkpoint the transaction log? Checkpoints make startup and shutdown faster. -# default: 20 * 1024 * 1024 -# bdb.checkpoint.interval.bytes= - - -# How often in ms should we checkpoint the transaction log -# default: 30000 -# bdb.checkpoint.interval.ms= - - -# Should we enabled the mysql storage engine? Doing so will create a connection pool that will be used for the mysql instance -# default: false -# enable.mysql.engine= - - -# The mysql username to user -# default: root -# mysql.user= - - -# The mysql password to user -# mysql.password= - - -# The host of the mysql instance -# default: localhost -# mysql.host= - - -# The port of the mysql instance -# default: 3306 -# mysql.port= - - -# The name of the mysql database -# default: voldemort -# mysql.database= - - -#Should we enable the memory storage engine? Might as well this takes no resources and is just here for consistency. -# default: true -# enable.memory.engine= - - -# Should we enable the cache storage engine? Might as well this takes no resources and is just here for consistency. -# default: true -# enable.cache.engine= - - -# Should we enable the readonly storage engine? -# default: false -# enable.readonly.engine= - - -# The maximum time to wait to acquire a filehandle to perform reads. -# default: 4000 -# readonly.file.wait.timeout.ms= - - -# The number of backup copies of the data to keep around for rollback. -# default: 1 -# readonly.backups= - - -# The number of file descriptors to pool per store. -# default: 5 -# readonly.file.handles= - - -# The directory in which to store readonly data files. -# default: ${data.directory}/read-only -# readonly.data.directory= - - -# What storage engine should we use for storing misdelivered messages that need to be rerouted? -# default: bdb -# slop.store.engine= - - -# The maximum number of threads the server can use. -# default: 100 -# max.threads= - - -# The number of threads to keep alive even when idle. -# default: max(1, ${max.threads} / 2) -# core.threads= - - -# The socket SO_TIMEOUT. Essentially the amount of time to block on a low-level network operation before throwing an error. -# default: 4000 -# socket.timeout.ms= - - -# The total amount of time to wait for adequate responses from all nodes before throwing an error. -# default: 5000 -# routing.timeout.ms= - - -# Enable the HTTP data server? -# default: true -# http.enable= - - -# Enable the socket data server? -# default: true -# socket.enable= - - -# Enable JMX monitoring? -# default: true -# jmx.enable= - - -# Enable detection of misdelivered messages for persistence and redelivery. -# default: false -# slop.detection.enable= - - -# Log every operation on all stores. -# default: true -# enable.verbose.logging= - - -# Track load statistics on the stores. -# default: true -# enable.stat.tracking= - - -# How often should misdelivered "slop" data be pushed out to nodes? -# default: 2 * 60 * 1000 -# pusher.poll.ms= - - -# The number of threads to use for scheduling periodic jobs -# default: 3 -# scheduler.threads= http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node1.properties ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node1.properties b/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node1.properties deleted file mode 100644 index a2081dd..0000000 --- a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/node1.properties +++ /dev/null @@ -1,207 +0,0 @@ -# -# Copyright (c) 2010 Niclas Hedhman . -# -# Licensed under the Apache License, Version 2.0 (the "License"); -# you may not use this file except in compliance with the License. -# You may obtain a copy of the License at -# -# http://www.apache.org/licenses/LICENSE-2.0 -# -# Unless required by applicable law or agreed to in writing, software -# distributed under the License is distributed on an "AS IS" BASIS, -# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or -# implied. -# -# See the License for the specific language governing permissions and -# limitations under the License. -# - -# The unique, sequential identifier for this server in the cluster (starts with 0) -# default: none, must be specfified -node.id=1 - -# The base directory for voldemort. Can also be specified via the environment variable VOLDEMORT_HOME or -# via a command line option. -# default: none -# voldemort.home= - -# The directory where voldemort data is stored -# default: ${voldemort.home}/data -# data.directory= - - -# The directory where voldemort configuration is stored -# default: ${voldemort.home}/config -# metadata.directory= - -# Should the BDB engine be enabled? -# default: true -# enable.bdb.engine= - - -# The BDB cache that is shared by all BDB tables. Bigger is better. -# default: 200MB (make it bigger!!!) -bdb.cache.size=50000000 - - -# Should transactions be immediately written to disk? -# default: false -# bdb.write.transactions= - -# When the transaction has been written to disk should we force the disk to flush the OS cache. This is a fairly expensive operation. -# default: false -# bdb.flush.transactions= - - -# The directory where the BDB environment is located -# default: ${data.directory}/bdb -# bdb.data.directory= - - -# The size of an individual log file -# default: 1GB -# bdb.max.logfile.size= - - -# The fanout size for the btree. Bigger fanout more effienciently supports larger btrees. -# default: 512 -# bdb.btree.fanout= - - -# How often (in bytes) should we checkpoint the transaction log? Checkpoints make startup and shutdown faster. -# default: 20 * 1024 * 1024 -# bdb.checkpoint.interval.bytes= - - -# How often in ms should we checkpoint the transaction log -# default: 30000 -# bdb.checkpoint.interval.ms= - - -# Should we enabled the mysql storage engine? Doing so will create a connection pool that will be used for the mysql instance -# default: false -# enable.mysql.engine= - - -# The mysql username to user -# default: root -# mysql.user= - - -# The mysql password to user -# mysql.password= - - -# The host of the mysql instance -# default: localhost -# mysql.host= - - -# The port of the mysql instance -# default: 3306 -# mysql.port= - - -# The name of the mysql database -# default: voldemort -# mysql.database= - - -#Should we enable the memory storage engine? Might as well this takes no resources and is just here for consistency. -# default: true -# enable.memory.engine= - - -# Should we enable the cache storage engine? Might as well this takes no resources and is just here for consistency. -# default: true -# enable.cache.engine= - - -# Should we enable the readonly storage engine? -# default: false -# enable.readonly.engine= - - -# The maximum time to wait to acquire a filehandle to perform reads. -# default: 4000 -# readonly.file.wait.timeout.ms= - - -# The number of backup copies of the data to keep around for rollback. -# default: 1 -# readonly.backups= - - -# The number of file descriptors to pool per store. -# default: 5 -# readonly.file.handles= - - -# The directory in which to store readonly data files. -# default: ${data.directory}/read-only -# readonly.data.directory= - - -# What storage engine should we use for storing misdelivered messages that need to be rerouted? -# default: bdb -# slop.store.engine= - - -# The maximum number of threads the server can use. -# default: 100 -# max.threads= - - -# The number of threads to keep alive even when idle. -# default: max(1, ${max.threads} / 2) -# core.threads= - - -# The socket SO_TIMEOUT. Essentially the amount of time to block on a low-level network operation before throwing an error. -# default: 4000 -# socket.timeout.ms= - - -# The total amount of time to wait for adequate responses from all nodes before throwing an error. -# default: 5000 -# routing.timeout.ms= - - -# Enable the HTTP data server? -# default: true -# http.enable= - - -# Enable the socket data server? -# default: true -# socket.enable= - - -# Enable JMX monitoring? -# default: true -# jmx.enable= - - -# Enable detection of misdelivered messages for persistence and redelivery. -# default: false -# slop.detection.enable= - - -# Log every operation on all stores. -# default: true -# enable.verbose.logging= - - -# Track load statistics on the stores. -# default: true -# enable.stat.tracking= - - -# How often should misdelivered "slop" data be pushed out to nodes? -# default: 2 * 60 * 1000 -# pusher.poll.ms= - - -# The number of threads to use for scheduling periodic jobs -# default: 3 -# scheduler.threads= http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/stores.xml ---------------------------------------------------------------------- diff --git a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/stores.xml b/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/stores.xml deleted file mode 100644 index a401733..0000000 --- a/extensions/entitystore-voldemort/src/test/resources/org/qi4j/entitystore/voldemort/stores.xml +++ /dev/null @@ -1,37 +0,0 @@ - - - - - qi4j-entities - 1 - 1 - 1 - 1 - 1 - bdb - client - - string - utf8 - - - identity - - - \ No newline at end of file http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/libraries.gradle ---------------------------------------------------------------------- diff --git a/libraries.gradle b/libraries.gradle index 86ad6e4..100213a 100644 --- a/libraries.gradle +++ b/libraries.gradle @@ -21,9 +21,7 @@ def asmVersion = '5.0.4' def bonecpVersion = '0.8.0.RELEASE' def bouncyVersion = '1.52' -def commonsCodecVersion = '1.10' def commonsDbcpVersion = '1.4' // Should be moved to commons-dbcp2 -def commonsIoVersion = '2.4' def commonsLangVersion = '2.6' // Should be moved to commons-lang3 def derbyVersion = '10.11.1.1' def dnsJavaVersion = '2.1.7' @@ -31,7 +29,6 @@ def ehcacheVersion = '2.10.0' def elasticsearchVersion = '1.6.0' def freemarkerVersion = '2.3.22' def groovyVersion = '2.4.3' -def guavaVersion = '18.0' def h2Version = '1.4.187' def hazelcastVersion = '3.5' def httpClientVersion = '4.2.2' // 4.3.4 exists @@ -40,7 +37,6 @@ def javascriptVersion = '1.7.7' def javasqlgeneratorVersion = '0.3.2' def jcloudsVersion = '1.9.0' def jdbmVersion = '2.4' -def jdomVersion = '2.0.2' def jedisVersion = '2.7.2' def jettyVersion = '9.2.11.v20150529' // 9.3.x Tests fail! def jgoodiesLooksVersion = '2.5.3' @@ -50,7 +46,6 @@ def jtaVersion = '1.1' def leveldbVersion = '0.7' def leveldbJniVersion = '1.8' def liquibaseVersion = '3.4.0' -def log4jVersion = '1.2.17' def logbackVersion = '1.1.3' def mongodbVersion = '2.13.2' // 3.0.x Fails to compile! def mysqlVersion = '5.1.35' @@ -66,14 +61,12 @@ def scalaVersion = '2.11.6' def servletVersion = '3.1.0' def shiroVersion = '1.2.3' def skedVersion = '2.1' -def sleepycatVersion = '5.0.73' def slf4jVersion = '1.7.12' def solrVersion = "1.4.1" // 4.8.1 Fails to compile! def springVersion = '4.1.7.RELEASE' def spymemcachedVersion = '2.12.0' def sqliteVersion = '3.8.10.1' def velocityVersion = '1.7' -def voldemortVersion = '1.3.0' def wicketVersion = '1.5.8' // 6.15.0 Samples fails to compile! def wicketStatelessVersion = '1.5.0' def woodstoxVersion = '4.4.1' @@ -111,7 +104,6 @@ rootProject.ext { // logging slf4j_api: "org.slf4j:slf4j-api:$slf4jVersion", slf4j_simple: "org.slf4j:slf4j-simple:$slf4jVersion", - log4j: 'log4j:log4j:' + log4jVersion, logback: 'ch.qos.logback:logback-classic:' + logbackVersion, jcl_slf4j: "org.slf4j:jcl-over-slf4j:$slf4jVersion", jcl_api: 'commons-logging:commons-logging-api:99.0-does-not-exist', //ensure it is never used. @@ -218,14 +210,8 @@ rootProject.ext { jta: "javax.transaction:jta:$jtaVersion", javaSqlGenerator: "org.java-sql-generator:org.java-sql-generator.api:$javasqlgeneratorVersion", javaSqlGeneratorImpl: "org.java-sql-generator:org.java-sql-generator.implementation:$javasqlgeneratorVersion", - voldemort: "org.immunogenomics.gl.voldemort:voldemort:$voldemortVersion", - guava: "com.google.guava:guava:$guavaVersion", - sleepycat: "com.sleepycat:je:$sleepycatVersion", - jdom: "org.jdom:jdom:$jdomVersion", velocity: "org.apache.velocity:velocity:$velocityVersion", - commons_codec: "commons-codec:commons-codec:$commonsCodecVersion", commons_dbcp: "commons-dbcp:commons-dbcp:$commonsDbcpVersion", - commons_io: "commons-io:commons-io:$commonsIoVersion", commons_lang: "commons-lang:commons-lang:$commonsLangVersion", servlet_api: "javax.servlet:javax.servlet-api:$servletVersion", http_client: "org.apache.httpcomponents:httpclient:$httpClientVersion", http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/manual/src/docs/userguide/extensions.txt ---------------------------------------------------------------------- diff --git a/manual/src/docs/userguide/extensions.txt b/manual/src/docs/userguide/extensions.txt index 7866ff5..511578f 100644 --- a/manual/src/docs/userguide/extensions.txt +++ b/manual/src/docs/userguide/extensions.txt @@ -109,10 +109,6 @@ include::../../../../extensions/entitystore-sql/src/docs/es-sql.txt[] :leveloffset: 2 -include::../../../../extensions/entitystore-voldemort/src/docs/es-voldemort.txt[] - -:leveloffset: 2 - include::../../../../extensions/indexing-elasticsearch/src/docs/index-elasticsearch.txt[] :leveloffset: 2 http://git-wip-us.apache.org/repos/asf/zest-qi4j/blob/294aa1d2/settings.gradle ---------------------------------------------------------------------- diff --git a/settings.gradle b/settings.gradle index da84170..a66fd66 100644 --- a/settings.gradle +++ b/settings.gradle @@ -72,7 +72,6 @@ include 'core:functional', 'extensions:entitystore-redis', 'extensions:entitystore-riak', 'extensions:entitystore-sql', - 'extensions:entitystore-voldemort', 'extensions:indexing-elasticsearch', 'extensions:indexing-rdf', 'extensions:indexing-solr',