Search in sources :

Example 1 with WatchEvent

use of org.apache.ignite.internal.metastorage.client.WatchEvent in project ignite-3 by apache.

the class WatchAggregatorTest method testEventsRouting.

@Test
public void testEventsRouting() {
    var watchAggregator = new WatchAggregator();
    var lsnr1 = mock(WatchListener.class);
    var lsnr2 = mock(WatchListener.class);
    watchAggregator.add(new ByteArray("1"), lsnr1);
    watchAggregator.add(new ByteArray("2"), lsnr2);
    var entryEvt1 = new EntryEvent(entry("1", "value1", 1, 1), entry("1", "value1n", 1, 1));
    var entryEvt2 = new EntryEvent(entry("2", "value2", 1, 1), entry("2", "value2n", 1, 1));
    watchAggregator.watch(1, (v1, v2) -> {
    }).get().listener().onUpdate(new WatchEvent(List.of(entryEvt1, entryEvt2)));
    var watchEvt1Res = ArgumentCaptor.forClass(WatchEvent.class);
    verify(lsnr1).onUpdate(watchEvt1Res.capture());
    assertEquals(List.of(entryEvt1), watchEvt1Res.getValue().entryEvents());
    var watchEvt2Res = ArgumentCaptor.forClass(WatchEvent.class);
    verify(lsnr2).onUpdate(watchEvt2Res.capture());
    assertEquals(List.of(entryEvt2), watchEvt2Res.getValue().entryEvents());
}
Also used : ArgumentMatchers.any(org.mockito.ArgumentMatchers.any) Arrays(java.util.Arrays) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) WatchListener(org.apache.ignite.internal.metastorage.client.WatchListener) ByteArray(org.apache.ignite.lang.ByteArray) Mockito.times(org.mockito.Mockito.times) Mockito.when(org.mockito.Mockito.when) StandardCharsets(java.nio.charset.StandardCharsets) Mockito.verify(org.mockito.Mockito.verify) HashSet(java.util.HashSet) Test(org.junit.jupiter.api.Test) Nullable(org.jetbrains.annotations.Nullable) List(java.util.List) ArgumentCaptor(org.mockito.ArgumentCaptor) KeyCriterion(org.apache.ignite.internal.metastorage.watch.KeyCriterion) WatchAggregator(org.apache.ignite.internal.metastorage.watch.WatchAggregator) Assertions.assertEquals(org.junit.jupiter.api.Assertions.assertEquals) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) NotNull(org.jetbrains.annotations.NotNull) Mockito.mock(org.mockito.Mockito.mock) Entry(org.apache.ignite.internal.metastorage.client.Entry) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) ByteArray(org.apache.ignite.lang.ByteArray) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) WatchAggregator(org.apache.ignite.internal.metastorage.watch.WatchAggregator) Test(org.junit.jupiter.api.Test)

Example 2 with WatchEvent

use of org.apache.ignite.internal.metastorage.client.WatchEvent in project ignite-3 by apache.

the class WatchListenerInhibitor method stopInhibit.

/**
 * Stops inhibit events.
 */
public synchronized void stopInhibit() {
    inhibit = false;
    for (WatchEvent evt : inhibitEvents) {
        realListener.onUpdate(evt);
    }
    inhibitEvents.clear();
}
Also used : WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent)

Example 3 with WatchEvent

use of org.apache.ignite.internal.metastorage.client.WatchEvent in project ignite-3 by apache.

the class DistributedConfigurationStorage method registerConfigurationListener.

/**
 * {@inheritDoc}
 */
@Override
public synchronized void registerConfigurationListener(@NotNull ConfigurationStorageListener lsnr) {
    if (this.lsnr == null) {
        this.lsnr = lsnr;
        // TODO: registerWatchByPrefix could throw OperationTimeoutException and CompactedException and we should
        // TODO: properly handle such cases https://issues.apache.org/jira/browse/IGNITE-14604
        metaStorageMgr.registerWatchByPrefix(DST_KEYS_START_RANGE, new WatchListener() {

            @Override
            public boolean onUpdate(@NotNull WatchEvent events) {
                Map<String, Serializable> data = new HashMap<>();
                Entry masterKeyEntry = null;
                for (EntryEvent event : events.entryEvents()) {
                    Entry e = event.newEntry();
                    if (e.key().equals(MASTER_KEY)) {
                        masterKeyEntry = e;
                    } else {
                        String key = e.key().toString().substring(DISTRIBUTED_PREFIX.length());
                        Serializable value = e.value() == null ? null : ConfigurationSerializationUtil.fromBytes(e.value());
                        data.put(key, value);
                    }
                }
                // That means that masterKey update must be included in the batch.
                assert masterKeyEntry != null;
                long newChangeId = masterKeyEntry.revision();
                assert newChangeId > changeId.get();
                changeId.set(newChangeId);
                lsnr.onEntriesChanged(new Data(data, newChangeId)).join();
                return true;
            }

            @Override
            public void onError(@NotNull Throwable e) {
                // TODO: need to handle this case and there should some mechanism for registering new watch as far as
                // TODO: onError unregisters failed watch https://issues.apache.org/jira/browse/IGNITE-14604
                LOG.error("Meta storage listener issue", e);
            }
        });
    } else {
        LOG.warn("Configuration listener has already been set.");
    }
}
Also used : WatchListener(org.apache.ignite.internal.metastorage.client.WatchListener) Entry(org.apache.ignite.internal.metastorage.client.Entry) VaultEntry(org.apache.ignite.internal.vault.VaultEntry) Serializable(java.io.Serializable) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) HashMap(java.util.HashMap) Map(java.util.Map)

Example 4 with WatchEvent

use of org.apache.ignite.internal.metastorage.client.WatchEvent in project ignite-3 by apache.

the class WatchAggregator method watchListener.

/**
 * Produces the watch listener, which will dispatch events to appropriate watches.
 *
 * @param storeRevision action to commit keys-revision pair to persistent store for processed keys.
 * @return watch listener, which will dispatch events to appropriate watches.
 */
private WatchListener watchListener(BiConsumer<Collection<IgniteBiTuple<ByteArray, byte[]>>, Long> storeRevision) {
    // Copy watches to separate collection, because all changes on the WatchAggregator watches
    // shouldn't be propagated to listener watches immediately.
    // WatchAggregator will be redeployed with new watches if needed instead.
    final LinkedHashMap<Long, Watch> cpWatches = new LinkedHashMap<>(watches);
    return new WatchListener() {

        @Override
        public boolean onUpdate(@NotNull WatchEvent evt) {
            // TODO: IGNITE-15858 Fix stopWatch may solve the issue.
            synchronized (watches) {
                processWatchEvents(evt);
            }
            return true;
        }

        /**
         * Process watch events synchronously.
         *
         * @param evt Watch event.
         */
        private void processWatchEvents(@NotNull WatchEvent evt) {
            var watchIt = cpWatches.entrySet().iterator();
            Collection<Long> toCancel = new ArrayList<>();
            while (watchIt.hasNext()) {
                Map.Entry<Long, Watch> entry = watchIt.next();
                Watch watch = entry.getValue();
                var filteredEvts = new ArrayList<EntryEvent>();
                for (EntryEvent entryEvt : evt.entryEvents()) {
                    if (watch.keyCriterion().contains(entryEvt.oldEntry().key())) {
                        filteredEvts.add(entryEvt);
                    }
                }
                if (!filteredEvts.isEmpty()) {
                    if (!watch.listener().onUpdate(new WatchEvent(filteredEvts))) {
                        watchIt.remove();
                        toCancel.add(entry.getKey());
                    }
                }
            }
            // to prevent finished watches from redeploy.
            if (!toCancel.isEmpty()) {
                cancelAll(toCancel);
            }
            var revision = 0L;
            var entries = new ArrayList<IgniteBiTuple<ByteArray, byte[]>>();
            for (EntryEvent entryEvt : evt.entryEvents()) {
                revision = entryEvt.newEntry().revision();
                entries.add(new IgniteBiTuple<>(entryEvt.newEntry().key(), entryEvt.newEntry().value()));
            }
            storeRevision.accept(entries, revision);
        }

        @Override
        public void onError(@NotNull Throwable e) {
            watches.values().forEach(w -> w.listener().onError(e));
        }
    };
}
Also used : WatchListener(org.apache.ignite.internal.metastorage.client.WatchListener) ArrayList(java.util.ArrayList) NotNull(org.jetbrains.annotations.NotNull) LinkedHashMap(java.util.LinkedHashMap) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) AtomicLong(java.util.concurrent.atomic.AtomicLong) ByteArray(org.apache.ignite.lang.ByteArray) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) LinkedHashMap(java.util.LinkedHashMap) Map(java.util.Map)

Example 5 with WatchEvent

use of org.apache.ignite.internal.metastorage.client.WatchEvent in project ignite-3 by apache.

the class WatchAggregatorTest method testCancel.

@Test
public void testCancel() {
    var watchAggregator = new WatchAggregator();
    var lsnr1 = mock(WatchListener.class);
    when(lsnr1.onUpdate(any())).thenReturn(true);
    var lsnr2 = mock(WatchListener.class);
    when(lsnr2.onUpdate(any())).thenReturn(true);
    final var id1 = watchAggregator.add(new ByteArray("1"), lsnr1);
    var id2 = watchAggregator.add(new ByteArray("2"), lsnr2);
    var entryEvt1 = new EntryEvent(entry("1", "value1", 1, 1), entry("1", "value1n", 1, 1));
    var entryEvt2 = new EntryEvent(entry("2", "value2", 1, 1), entry("2", "value2n", 1, 1));
    watchAggregator.watch(1, (v1, v2) -> {
    }).get().listener().onUpdate(new WatchEvent(List.of(entryEvt1, entryEvt2)));
    verify(lsnr1, times(1)).onUpdate(any());
    verify(lsnr2, times(1)).onUpdate(any());
    watchAggregator.cancel(id1);
    watchAggregator.watch(1, (v1, v2) -> {
    }).get().listener().onUpdate(new WatchEvent(List.of(entryEvt1, entryEvt2)));
    verify(lsnr1, times(1)).onUpdate(any());
    verify(lsnr2, times(2)).onUpdate(any());
}
Also used : ArgumentMatchers.any(org.mockito.ArgumentMatchers.any) Arrays(java.util.Arrays) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) WatchListener(org.apache.ignite.internal.metastorage.client.WatchListener) ByteArray(org.apache.ignite.lang.ByteArray) Mockito.times(org.mockito.Mockito.times) Mockito.when(org.mockito.Mockito.when) StandardCharsets(java.nio.charset.StandardCharsets) Mockito.verify(org.mockito.Mockito.verify) HashSet(java.util.HashSet) Test(org.junit.jupiter.api.Test) Nullable(org.jetbrains.annotations.Nullable) List(java.util.List) ArgumentCaptor(org.mockito.ArgumentCaptor) KeyCriterion(org.apache.ignite.internal.metastorage.watch.KeyCriterion) WatchAggregator(org.apache.ignite.internal.metastorage.watch.WatchAggregator) Assertions.assertEquals(org.junit.jupiter.api.Assertions.assertEquals) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) NotNull(org.jetbrains.annotations.NotNull) Mockito.mock(org.mockito.Mockito.mock) Entry(org.apache.ignite.internal.metastorage.client.Entry) EntryEvent(org.apache.ignite.internal.metastorage.client.EntryEvent) ByteArray(org.apache.ignite.lang.ByteArray) WatchEvent(org.apache.ignite.internal.metastorage.client.WatchEvent) WatchAggregator(org.apache.ignite.internal.metastorage.watch.WatchAggregator) Test(org.junit.jupiter.api.Test)

Aggregations

WatchEvent (org.apache.ignite.internal.metastorage.client.WatchEvent)6 EntryEvent (org.apache.ignite.internal.metastorage.client.EntryEvent)5 WatchListener (org.apache.ignite.internal.metastorage.client.WatchListener)5 Entry (org.apache.ignite.internal.metastorage.client.Entry)4 ByteArray (org.apache.ignite.lang.ByteArray)4 NotNull (org.jetbrains.annotations.NotNull)4 StandardCharsets (java.nio.charset.StandardCharsets)3 Arrays (java.util.Arrays)3 HashSet (java.util.HashSet)3 List (java.util.List)3 KeyCriterion (org.apache.ignite.internal.metastorage.watch.KeyCriterion)3 WatchAggregator (org.apache.ignite.internal.metastorage.watch.WatchAggregator)3 Nullable (org.jetbrains.annotations.Nullable)3 Assertions.assertEquals (org.junit.jupiter.api.Assertions.assertEquals)3 Test (org.junit.jupiter.api.Test)3 ArgumentCaptor (org.mockito.ArgumentCaptor)3 ArgumentMatchers.any (org.mockito.ArgumentMatchers.any)3 Mockito.mock (org.mockito.Mockito.mock)3 Mockito.times (org.mockito.Mockito.times)3 Mockito.verify (org.mockito.Mockito.verify)3