Re: Sizing in Ignite

2017-05-16 Thread vkulichenko
What you quote is just an example emphasizing that Ignite and relational DB are completely different storages and that mapping memory estimates one by one are wrong. You should use the actual guide for calculations that doesn't mention any multipliers like this. -Val -- View this message in con

Re: Ignite 1.6.0 suspected memory leak from DynamicCacheDescriptor

2017-05-16 Thread vkulichenko
Hi, It looks like there is client node constantly joining and leaving topology. What is the reason for this? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Ignite-1-6-0-suspected-memory-leak-from-DynamicCacheDescriptor-tp9443p12894.html Sent from the Apac

Re: Failed to wait for initial partition map exchange

2017-05-16 Thread vkulichenko
Jai, So what is the result of investigation? Does it look like memory issue or not? As I said earlier, the issue itself doesn't have generic solution, you need to find out the reason. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Failed-to-wait-for-initi

Re: Write behind and eventual consistency

2017-05-04 Thread vkulichenko
If it's this kind of batch processing, and if you're still waiting for a batch to be processed completely before the next one can be processed, why do you want to use write-behind? What is wrong with sync write-through in this case? -Val -- View this message in context: http://apache-ignite-us

Re: Ignite Web Sessions Caching Failover question

2017-04-28 Thread vkulichenko
Hi Rishi, I'm not sure I understand your concerns. First of all, web session clustering is not always used with Spring Boot. We just provide a web filter which can be used in any servlet based application. Second of all, the filter currently blocks with timeout or fails with exception in case clie

Re: Ignite Web Sessions Caching Failover question

2017-04-27 Thread vkulichenko
It seems that it will always throw an exception in this scenario. However it makes sense to me, are you willing to contribute this improvement? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Ignite-Web-Sessions-Caching-Failover-question-tp12240p12286.html

RE: Write behind and eventual consistency

2017-04-27 Thread vkulichenko
Hi Steve, What is the business use case behind this? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Write-behind-and-eventual-consistency-tp12242p12285.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Write behind and eventual consistency

2017-04-26 Thread vkulichenko
There is no way to do this. However, you can take a look at GridCacheWriteBehindStore which implements this functionality and try tweaking it so that the queue size is exposed somehow. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Write-behind-and-eventua

Re: how can I delete shutdownhook add by ignite?

2017-04-26 Thread vkulichenko
You can set -DIGNITE_NO_SHUTDOWN_HOOK=true system property to disable built in shutdown hook. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/how-can-I-delete-shutdownhook-add-by-ignite-tp12254p12255.html Sent from the Apache Ignite Users mailing list archi

Re: Write behind and eventual consistency

2017-04-25 Thread vkulichenko
Hi Steve, I don't think it's currently possible and frankly I'm not sure I understand what it actually means. Can you clarify what is implied in "no more write behind operations waiting for completion"? We could probably check if the queue is empty, but what if new updates happen right after or co

Re: How to set Xmx /Xms on embedded client

2017-04-25 Thread vkulichenko
Responded here: http://apache-ignite-users.70518.x6.nabble.com/XMX-XMS-for-embedded-ignite-in-client-mode-td12244.html -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/How-to-set-Xmx-Xms-on-embedded-client-tp12243p12246.html Sent from the Apache Ignite Users

Re: XMX/XMS for embedded ignite in client mode

2017-04-25 Thread vkulichenko
JVM parameters are set for JVM, not for an Ignite node. So basically the correct way depends on how your application is organized and started. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/XMX-XMS-for-embedded-ignite-in-client-mode-tp12244p12245.html Sent

Re: Creating a distributed cache via cacheManager (JCACHE)

2017-04-18 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. mikep-sl wrote > I have the same problem. The caches are are

Re: How do I provide AffinityFunction.BackupFilter when mainly using C++ bindings

2017-04-18 Thread vkulichenko
You can use APIs only on one of them, or create a cluster of two server nodes, embed a client in the application and use APIs there. In any case, I don't see why you need custom affinity function or even backup filter. And your understanding of backup filter is not correct. Primary node for a part

Re: Persisting data to cassandra tables.

2017-04-14 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. Jenny B. wrote > Hi > > I am writing this test for a POC wit

Re: How do I provide AffinityFunction.BackupFilter when mainly using C++ bindings

2017-04-13 Thread vkulichenko
Why not create two equal C++ nodes and use both of them? You will give you data redundancy and load balancing, without any custom affinity functions. Your model seems to be worse and also requires more effort. I would recommend to use abilities provided by Ignite out of the box. -Val -- View t

Re: How do I provide AffinityFunction.BackupFilter when mainly using C++ bindings

2017-04-13 Thread vkulichenko
Hi, There is no way to do this unless you implement your own affinity function. Out of the box you can control whether a particular node can be used as a partition backup having primary node for this partition already assigned. What is the purpose of such deployment? What are you trying to achiev

Re: Help with Web agent

2017-04-13 Thread vkulichenko
Harish, You need to put JDBC driver for you database into jdbc-drivers folder. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Help-with-Web-agent-tp11932p11937.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Ignite client deployed on Tomcat is not able to make secure connection with standalone Ignite Server

2017-04-13 Thread vkulichenko
Hi Ankit, This configuration is done on Ignite level, there is nothing specific to Tomcat. Is there any difference between Ignite configurations on different clients? Are all certificates available, etc.? How does the issue looks like? Is there an exception? -Val -- View this message in contex

Re: Concurrent job execution and FifoQueueCollisionSpi.parallelJobsNumber=1

2017-04-13 Thread vkulichenko
Hi Ryan, I will take a look at your sample in the next few days. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Concurrent-job-execution-and-FifoQueueCollisionSpi-parallelJobsNumber-1-tp8697p11935.html Sent from the Apache Ignite Users mailing list archiv

Re: Concurrent job execution and FifoQueueCollisionSpi.parallelJobsNumber=1

2017-04-11 Thread vkulichenko
Ryan, No, there are no known issues like that and I don't think there will be a way to investigate it without being able to reproduce. Please let us know if you have a reproducer. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Concurrent-job-execution-and

Re: External data sources

2017-04-11 Thread vkulichenko
Dmitri, Correct, there are no plans. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/External-data-sources-tp11766p11883.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Client near cache with Apache Flink

2017-04-11 Thread vkulichenko
Both. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Client-near-cache-with-Apache-Flink-tp11627p11881.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Client near cache with Apache Flink

2017-04-10 Thread vkulichenko
Primary node is calculated for a particular key, this is done by affinity function. This function is stateless and does not depend on weather value exists in cache or not, so the request will always go to the primary node for requested key. In case you have near cache, and value for requested key i

Re: Client near cache with Apache Flink

2017-04-09 Thread vkulichenko
"Real time streaming should not go through network io all the time." - can you please clarify what exactly you mean by this? For which operations do you want to avoid io? What is the actual use case scenario? Please describe it in more detail. Ignite always sends request only to primary node for a

Re: Identical objects on the same node

2017-04-09 Thread vkulichenko
Hi Steve, The rational is simple - Ignite is a key-value storage. Locks, read and write operations, etc. - all done on per entry level, and applying optimizations like this would complicate things drastically, even if they are possible. If you want to avoid duplication, you should normalize the d

Re: Client near cache with Apache Flink

2017-04-09 Thread vkulichenko
Hi Nuno, First of all, Ignite does not query all nodes when you do a read with near cache. It first checks locally, and it if value is not available, goes to primary node. Second of all, it still sounds like near cache is not what you need and you chose incorrect approach in the first place. How

Re: External data sources

2017-04-08 Thread vkulichenko
Dmitri, The main advantage of Ignite SQL is in-memory indexing that allows to achieve super-fast query performance. I believe it's not possible to add arbitrary external data sources without losing this. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Exte

Re: Client connection events fails when visor is open

2017-04-08 Thread vkulichenko
Currently Visor runs in server mode by default, so as long as it's up, client do not disconnect from Visor topology. If you want to avoid this, you can explicitly set clientMode flag on Visor configuration. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Cl

Re: Identical objects on the same node

2017-04-08 Thread vkulichenko
If you're talking about values, then all of them are serialized and stored separately. There are no optimizations like you described. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Identical-objects-on-the-same-node-tp11830p11834.html Sent from the Apache

Re: Client near cache with Apache Flink

2017-04-08 Thread vkulichenko
This seems to be correct behavior. When you read a value through near cache for the first time, you actually create a new entry in near cache and also add a reader on the server node (basically it's a node ID that server node uses to update near cache when value is changed). So near cache does prov

Re: Compute Grid - StackOverflow

2017-04-08 Thread vkulichenko
Yes, it fails on one of the arguments, but having only trace it's impossible to say what is exactly wrong there. You should check this with a debugger. Marshaller is always enabled, of course. If you do not provide any in the config, default serialization format is used: https://apacheignite.readm

Re: Wait till the cache loading is complete before querying through ignite client

2017-04-08 Thread vkulichenko
Thanks for sharing! -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Wait-till-the-cache-loading-is-complete-before-querying-through-ignite-client-tp9643p11831.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Stoppin listen for topics in Ignite

2017-04-05 Thread vkulichenko
This doesn't make a lot of sense, because "during stop" is not defined. From your code standpoint, stopListen() is an atomic "immediate" operation, and any message can be received before of after this operation. You should call stopListen() only if you don't intend to receive messages anymore. -Va

Re: Runtime error caught during grid runnable execution: GridWorker

2017-04-05 Thread vkulichenko
Different application instances are usually deployed with different class loaders, so that they are completely independent from each other, including any static content. For example, if there are two instances, they will not know about each other's Ignite instances. Each of them should start Ignite

Re: Stoppin listen for topics in Ignite

2017-04-03 Thread vkulichenko
Sorry, I don't understand. Why do you call stopListen if you still can receive messages? Basically, if you do this concurrently, there is a race condition and you don't know whether listener will be called or not for all messages. -Val -- View this message in context: http://apache-ignite-user

Re: Stoppin listen for topics in Ignite

2017-04-02 Thread vkulichenko
Not sure I understood the question correctly, but if you want to listen for messages sent via IgniteMessaging API, refer to this documentation: https://apacheignite.readme.io/docs/messaging -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Stoppin-listen-for-

Re: 2.0

2017-04-01 Thread vkulichenko
Anil, I'm not sure I understand what is the issue in the first place. What is not working? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/2-0-tp11487p11640.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Compute Grid - StackOverflow

2017-03-31 Thread vkulichenko
vitaly v wrote > WorkItemClient - is third party class provided by Micrisoft. We use its > TFS SDK in our application. > WorkItemClient object take part inside of call(...) that we are passed to > cluster for execution. > > After removing marshaller both from client and server- I've got next log >

Re: Client near cache with Apache Flink

2017-03-31 Thread vkulichenko
Honestly, it's absolutely not clear what you're doing. Can you better describe your use case? Throughput for which operations are you measuring? What are you comparing with (i.e. what did you use before Ignite for data storage)? Give as much information as possible. -Val -- View this message in

Re: 2.0

2017-03-31 Thread vkulichenko
Yes, this warning is OK. It just indicates that default client configuration is used. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/2-0-tp11487p11633.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

RE: IGFS Usage Question

2017-03-31 Thread vkulichenko
If you're using java.io.File, then no, it's not possible. You will have to write the code that starts Ignite, creates IgniteFileSystem, etc. At the same time, all IGFS streams extend standard Java streams, so you should be able to reuse most of you code that read and writes to files. -Val -- V

Re: Stoppin listen for topics in Ignite

2017-03-31 Thread vkulichenko
You should provide the same instance of listener to stop method: listener = (nodeId, msg) -> { ... } rmtMsg.localListen("MyOrderedTopic", listener) ... rmtMsg.stopLocalListen("MyOrderedTopic", listener) -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Stopp

Re: Need to use Index along with Transactional feature

2017-03-30 Thread vkulichenko
shivendra singh wrote > Are you saying, I can use same TRANSACTIONAL cache for querying thru > index. I only need to handle dirty read condition at few place in my code. Yes, there are no limitations that depend on cache atomicity mode. -Val -- View this message in context: http://apache-igni

Re: IGFS Usage Question

2017-03-30 Thread vkulichenko
Hi Chris, Ignite provides IGFS based implementation of Hadoop file system abstraction. So you can use run you Hadoop applications without changes and connect them directly to in-memory FS. Did you go through installation instructions [1]? [1] https://apacheignite-fs.readme.io/docs/installing-on-a

Re: Integrate Enterprise license.xml in Springboot application?

2017-03-30 Thread vkulichenko
Hi, This is Apache Ignite community forum. Please contact GridGain directly with questions about their products. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Integrate-Enterprise-license-xml-in-Springboot-application-tp11583p11588.html Sent from the Apa

Re: Ignite Client Auto Reconnect after a Ignite cluster restart

2017-03-30 Thread vkulichenko
Raja, Client should actually reconnect automatically. Please attach logs from both client and server. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Ignite-Client-Auto-Reconnect-after-a-Ignite-cluster-restart-tp11586p11587.html Sent from the Apache Ignite

Re: Need to use Index along with Transactional feature

2017-03-30 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. shivendra singh wrote > I want to use Index on a pojos that I

Re: Compute Grid - StackOverflow

2017-03-30 Thread vkulichenko
What is WorkItemClient class and why it is not Serializable? Is it supposed to be serialized in the first place? Also I didn't mean to use JDK marshaller, but rather use the default serialization protocol. Just remove any marshaller configuration to enable it. -Val -- View this message in cont

Re: 2.0

2017-03-30 Thread vkulichenko
Anil, So it's coming from vertx then. I would refer to their documentation and other resources to understand why this warning is shown (my guess is that it's specific to AWS). As I said, Ignite node is started successfully. -Val -- View this message in context: http://apache-ignite-users.7051

Re: Compute Grid - StackOverflow

2017-03-29 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. vitaly v wrote > hello, I am making first steps in Appache Ig

Re: Fail to join topology and repeat join process

2017-03-29 Thread vkulichenko
Did you try suggestions given by Vladislav? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Fail-to-join-topology-and-repeat-join-process-tp6987p11554.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Akka vs Ignite

2017-03-29 Thread vkulichenko
Aleksey, I think the difference between the products is more in functionality and APIs provided to user. As Nikita correctly mentioned, Ignite provides much higher level abstractions. For sure, Akka architecture can have a lot of similarities with low-level architecture of certain Ignite component

Re: 2.0

2017-03-29 Thread vkulichenko
Hi Anil, What is the MacAddressUtil class? I can't find it in any of Ignite dependencies, is it coming from your code? In any case, it looks like the node is started, so there are no issues with discovery. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/2-

Re: max size on cache

2017-03-28 Thread vkulichenko
Hi Rishi, Eviction policies allow to specify limits: https://apacheignite.readme.io/docs/evictions -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/max-size-on-cache-tp11523p11524.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Cache get using sub-fields of composite key

2017-03-28 Thread vkulichenko
To execute get() you need the whole key object that will be equal to the one used for update. To query by one of the fields you can use SQL: https://apacheignite.readme.io/docs/sql-grid -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Cache-get-using-sub-fie

Re: Insert data in hdfs using ignite

2017-03-28 Thread vkulichenko
Prashant, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. Prashant Singh wrote > This problem is resolved now. Pl

Re: Distributed Closures VS Executor Service

2017-03-28 Thread vkulichenko
kmandalas wrote* > One question is * > : if some Job fails and other Jobs belonging to the same Task are still > running (in the same or other grid nodes), is it possible to cancel them > and abort the whole Task before waiting for all of them to finish? This will happen if result() method throws

Re: Distributed Closures VS Executor Service

2017-03-28 Thread vkulichenko
-- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Distributed-Closures-VS-Executor-Service-tp11192p11517.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Does operations through entry processor blocks the regular GETs?

2017-03-28 Thread vkulichenko
As Denis mentioned, entry is locked while entry processor is executed, so you can't read it. Entry processor is supposed to be as lightweight as possible, you should avoid putting heavy long-running logic there. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.c

Re: What is the best approach for large number of concurrent mappings?

2017-03-27 Thread vkulichenko
Hi, Can you please clarify what you mean by continuous mapper here? Actually, your use case sounds similar to one implemented in the WordCount example provided with Ignite: https://github.com/apache/ignite/tree/master/examples/src/main/java/org/apache/ignite/examples/streaming/wordcount -Val -

Re: IgniteThread ThreadLocal Memory Leak

2017-03-14 Thread vkulichenko
Isaeed, There is no such way. If you're using thread local, you should properly clean it when the value is not needed anymore. Another way it to use something else instead. Why are you using thread locals in compute in the first place? What is the use case for this? -Val -- View this messag

Re: Understanding faster batch inserts/updates with apache ignite 1.9

2017-03-14 Thread vkulichenko
1. Yes, it's using IgniteDataStreamer under the hood and even has the same parameters. 2. DML also implies query parsing, mapping to Java objects and other preparation steps before IgniteDataStreamer API is called. Thus the performance difference. -Val -- View this message in context: http://a

Re: IGNITE-4106

2017-03-14 Thread vkulichenko
Hi Anil, I tried to run your project and also didn't get the exception. Please provide exact steps how to run it in order to reproduce the behavior. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/IGNITE-4106-tp11073p11169.html Sent from the Apache Ignite

Re: REST service command LOG

2017-03-14 Thread vkulichenko
Hi Sam, This makes sense to me. Can you create a ticket and put your thoughts there? Contributions are also very welcome ;) -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/REST-service-command-LOG-tp10148p11162.html Sent from the Apache Ignite Users mailin

Re: Ignite.NET ReadThrough?

2017-03-13 Thread vkulichenko
Hi, First of all, it sounds like you misunderstood the read-though. It is used ONLY if entry does not exist in cache yet. If you read a value that is already in cache, cache will never go the database, even if the value was updated there, because cache simply doesn't know about it. You should avo

Re: Aggregation of log files

2017-03-10 Thread vkulichenko
Is this a client? If so, it's a bad practice to create a new one for each operations. Start it once within your application and reuse. It's thread safe and can be used concurrently as well. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Aggregation-of-log-

Re: Understanding faster batch inserts/updates with apache ignite 1.9

2017-03-10 Thread vkulichenko
This is about JBDC driver and DML updates. IgniteJdbcDriver now has streaming mode in which all updates will be propagated to the cluster though IgniteDataStreamer. Otherwise they will executed separately without batching. -Val -- View this message in context: http://apache-ignite-users.70518.

Re: Apache Ignite cluster with Multicast IP Startegy

2017-03-10 Thread vkulichenko
Are you running two nodes on different machines? It looks like multicast is not working in your network (which is often the case), and nodes do not discover each other because the only address provided is 127.0.0.1. I would recommend to try static configuration providing correct addresses: https:/

Re: Aggregation of log files

2017-03-10 Thread vkulichenko
Can you clarify what you mean by "file per session"? What is session? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Aggregation-of-log-files-tp11102p11123.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Documentation improvements

2017-03-10 Thread vkulichenko
Hi Fede, You should create your own account on readme.io and use it to login. 'Suggest Edits' function is available to everyone, no special permissions needed. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Documentation-improvements-tp11106p11107.html Se

Re: Use of the EventStorageSpi

2017-03-10 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. Sylvain wrote > Hi, > > we found that the MemoryEventStorage

Re: AtomicSequence usage questions

2017-03-10 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. waterg wrote > Hello everyone, > > I've just started using

Re: Ignite client reconnect error

2017-03-10 Thread vkulichenko
IGNITE-2766 is not fixed yet, and I think overriding and tweaking SpringCacheManager is currently the only way to work around the problem. Would be great if you configure your change to the project. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Ignite-cli

Re: getOrCreateCache hang

2017-03-09 Thread vkulichenko
Hi Matt, First of all, this is a community forum and it's not a place for disappointment :) Nikolai is not obligated to help and I'm sure he is trying his best when doing this. I managed to reproduce the hang though. It happens simply because you have two projects (why?) that don't share classes.

Re: Is it safe to use NTP time synchronization system on different ignite nodes?

2017-03-09 Thread vkulichenko
No, it does not. There is CLOCK synchronization mode in atomic cache, but Ignite has it's own clock server to sync time. Moreover, this mode is not default one, not recommended and will be discontinued soon. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/I

Re: NullPointerException for @LoggerResource

2017-03-07 Thread vkulichenko
Just use different name, the one that doesn't start with 'org.apache.ignite'. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/NullPointerException-for-LoggerResource-tp11037p11051.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: NullPointerException for @LoggerResource

2017-03-07 Thread vkulichenko
setNodeAttributes is an SPI interface method and therefore is supposed to be invoked only by Ignite, not by your code. To add attributes to a node, use IgniteConfiguration#setUserAttributes. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/NullPointerExcepti

Re: CacheStore.loadCache loading data for 1024 partitions for a single node

2017-03-07 Thread vkulichenko
Why is it too high? Is it causing any problems? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/CacheStore-loadCache-loading-data-for-1024-partitions-for-a-single-node-tp11028p11048.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Very slow cache query compared to H2

2017-03-06 Thread vkulichenko
That would be the best way :) -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Very-slow-cache-query-compared-to-H2-tp11013p11036.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: CacheStore.loadCache loading data for 1024 partitions for a single node

2017-03-06 Thread vkulichenko
This is correct behavior. If there is only one node in topology, it holds all 1024 partitions for the cache. Once you add one more node, you will notice that partitions are distributed across topology. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/CacheSt

Re: Best way to update the partition id in database after rebalancing

2017-03-06 Thread vkulichenko
There is no need to do this. Key to partition mapping is constant and doesn't depend on how many nodes are in topology. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Best-way-to-update-the-partition-id-in-database-after-rebalancing-tp11026p11033.html Sent

Re: Runtime error caught during grid runnable execution: GridWorker

2017-03-03 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. abhijitprusty wrote > 05:52:20,310 INFO [org.jboss.web] (Ser

Re: Runtime error caught during grid runnable execution

2017-03-03 Thread vkulichenko
Hi, Please properly subscribe to the mailing list so that the community can receive email notifications for your messages. To subscribe, send empty email to user-subscr...@ignite.apache.org and follow simple instructions in the reply. abhijitprusty wrote > facing same sort of error > > 05:52:2

Re: Same Affinity For Same Key On All Caches

2017-03-02 Thread vkulichenko
Hi Alex, I see your point. Can you please outline its advantages vs rendezvous function? In my view issue discussed here makes it pretty much useless in vast majority of use cases, and very error-prone in all others. -Val -- View this message in context: http://apache-ignite-users.70518.x6.n

Re: Whole cache-entries in log-files found

2017-03-02 Thread vkulichenko
Hi Peter, Starting with 1.9 (which is about to be released) it will be possible to avoid key-value printout by setting this system property: -DIGNITE_TO_STRING_INCLUDE_SENSITIVE=true -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Whole-cache-entries-in-l

Re: Ignite RoundRobinLoadBalancingSpi Per Task not distributing tasks.

2017-03-02 Thread vkulichenko
Hi Ramzinator, For you case you just should not set perTask to true. What was the reason for setting it in the first place? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Ignite-RoundRobinLoadBalancingSpi-Per-Task-not-distributing-tasks-tp10991p11002.html

Re: Disabling Ignite console logs

2017-03-02 Thread vkulichenko
Neeraj, This will be fixed in 2.0: https://issues.apache.org/jira/browse/IGNITE-4248 -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Disabling-Ignite-console-logs-tp10990p11001.html Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Unexpected flag value

2017-03-02 Thread vkulichenko
Anil, Something must have changed in your application then, I don't believe in magic :) In any case, 'select *' currently includes _key and _val fields which represent key and value objects. If you don't have classes on client side (which is most likely the case when JDBC driver is used), this qu

Re: consistence issue

2017-03-01 Thread vkulichenko
Hi Shawn, 1. Yes, they will. 2. If invoke() call was successfully completed, then you have a guarantee that entry was updated. Of course, there is a chance that failure happens before that, in which case you don't know the result. 3. Yes, in case of graceful stop it will wait for already started o

Re: Data streamers: How to ensure loading data for the current partition only

2017-03-01 Thread vkulichenko
Sumanta, Streamer is generally used on a client node to stream data into the cluster. It only can be created by your code, so you have full control on how many streamers are there. If you want to pull data directly from server nodes, use CacheStore.loadCache instead. -Val -- View this message

Re: Unexpected flag value

2017-03-01 Thread vkulichenko
Hi, I would recommend to check that JDBC driver version is the same as Ignite version on server side. Can you also show the query and clarify what do you mean by "run query explicitely"? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Unexpected-flag-val

Re: Same Affinity For Same Key On All Caches

2017-03-01 Thread vkulichenko
Andrew, Yes, I believe it's a bug, let's create a ticket. Do you have any idea why this happens? The function doesn't have any state, so I don't see any difference between two its instances on same node for different caches, and two instances on different nodes for the same cache. This makes me t

Re: SpringTransactionManager - Participating in existing transactions is not supported

2017-02-28 Thread vkulichenko
Please refer to this page for all the information about contributing and process description: https://ignite.apache.org/community/contribute.html#contribute I don't think there is a ticket for this issue, so first thing would be to create it. -Val -- View this message in context: http://apach

Re: Lucene like Contains phrase query

2017-02-28 Thread vkulichenko
Ranjit, It looks like you don't have Ignite libraries on Spark executor's classpath. Please refer to Spark documentation for information on how to do this. You will probably use 'spark.jars.packages' or similar. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.

Re: Data streamers: How to ensure loading data for the current partition only

2017-02-28 Thread vkulichenko
IgniteDataStreamer is supposed to be running on a single node loading all the data. It will automatically map entries to correct nodes, batch them and stream efficiently. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Data-streamers-How-to-ensure-loading-d

Re: backup to swap

2017-02-28 Thread vkulichenko
Anil, As discussed before, you can try to implement your own eviction policy to achieve what you want to achieve. See Andrey's suggestion on how to check if a node is primary or backup. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/backup-to-swap-tp10255

Re: Lucene like Contains phrase query

2017-02-27 Thread vkulichenko
Ranjit, Everything is in memory. Full text index should work for you in my view. Can you clarify what problems do you have with it? -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Lucene-like-Contains-phrase-query-tp10808p10934.html Sent from the Apache Ig

Re: Same Affinity For Same Key On All Caches

2017-02-27 Thread vkulichenko
Andrey, Is there an explanation for this? If this all is true, it sounds like a bug to me, and pretty serious one. Alper, what is the reason for using fair affinity function? Do you have the same behavior with rendezvous (the default one)? -Val -- View this message in context: http://apache-

Re: Node discovery using ActiveMQ

2017-02-27 Thread vkulichenko
This implementation was removed and currently there is only one out of the box, based on TCP. I would highly recommend to use unless there is a very strong reason to do otherwise. -Val -- View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Node-discovery-using-ActiveMQ

<    1   2   3   4   5   6   7   8   9   10   >