Search in sources :

Example 11 with GroupPartitionId

use of org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId in project ignite by apache.

the class SnapshotFutureTask method onCheckpointBegin.

/**
 * {@inheritDoc}
 */
@Override
public void onCheckpointBegin(Context ctx) {
    if (stopping())
        return;
    assert !processed.isEmpty() : "Partitions to process must be collected under checkpoint mark phase";
    wrapExceptionIfStarted(() -> snpSndr.init(processed.values().stream().mapToInt(Set::size).sum())).run();
    // there is no error happen on task init.
    if (!startedFut.onDone())
        return;
    // Submit all tasks for partitions and deltas processing.
    List<CompletableFuture<Void>> futs = new ArrayList<>();
    if (log.isInfoEnabled()) {
        log.info("Submit partition processing tasks to the snapshot execution pool " + "[map=" + compactGroupPartitions(partFileLengths.keySet()) + ", totalSize=" + U.humanReadableByteCount(partFileLengths.values().stream().mapToLong(v -> v).sum()) + ']');
    }
    Collection<BinaryType> binTypesCopy = cctx.kernalContext().cacheObjects().metadata(Collections.emptyList()).values();
    // Process binary meta.
    futs.add(CompletableFuture.runAsync(wrapExceptionIfStarted(() -> snpSndr.sendBinaryMeta(binTypesCopy)), snpSndr.executor()));
    List<Map<Integer, MappedName>> mappingsCopy = cctx.kernalContext().marshallerContext().getCachedMappings();
    // Process marshaller meta.
    futs.add(CompletableFuture.runAsync(wrapExceptionIfStarted(() -> snpSndr.sendMarshallerMeta(mappingsCopy)), snpSndr.executor()));
    // Send configuration files of all cache groups.
    for (CacheConfigurationSender ccfgSndr : ccfgSndrs) futs.add(CompletableFuture.runAsync(wrapExceptionIfStarted(ccfgSndr::sendCacheConfig), snpSndr.executor()));
    try {
        for (Map.Entry<Integer, Set<Integer>> e : processed.entrySet()) {
            int grpId = e.getKey();
            String cacheDirName = pageStore.cacheDirName(grpId);
            // Process partitions for a particular cache group.
            for (int partId : e.getValue()) {
                GroupPartitionId pair = new GroupPartitionId(grpId, partId);
                Long partLen = partFileLengths.get(pair);
                CompletableFuture<Void> fut0 = CompletableFuture.runAsync(wrapExceptionIfStarted(() -> {
                    snpSndr.sendPart(getPartitionFile(pageStore.workDir(), cacheDirName, partId), cacheDirName, pair, partLen);
                    // Stop partition writer.
                    partDeltaWriters.get(pair).markPartitionProcessed();
                }), snpSndr.executor()).runAfterBothAsync(cpEndFut, wrapExceptionIfStarted(() -> {
                    File delta = partDeltaWriters.get(pair).deltaFile;
                    try {
                        // Atomically creates a new, empty delta file if and only if
                        // a file with this name does not yet exist.
                        delta.createNewFile();
                    } catch (IOException ex) {
                        throw new IgniteCheckedException(ex);
                    }
                    snpSndr.sendDelta(delta, cacheDirName, pair);
                    boolean deleted = delta.delete();
                    assert deleted;
                }), snpSndr.executor());
                futs.add(fut0);
            }
        }
        int futsSize = futs.size();
        CompletableFuture.allOf(futs.toArray(new CompletableFuture[futsSize])).whenComplete((res, t) -> {
            assert t == null : "Exception must never be thrown since a wrapper is used " + "for each snapshot task: " + t;
            closeAsync();
        });
    } catch (IgniteCheckedException e) {
        acceptException(e);
    }
}
Also used : IgniteInternalFuture(org.apache.ignite.internal.IgniteInternalFuture) MappedName(org.apache.ignite.internal.processors.marshaller.MappedName) PageStore(org.apache.ignite.internal.pagemem.store.PageStore) GridFutureAdapter(org.apache.ignite.internal.util.future.GridFutureAdapter) IgniteSnapshotManager.copy(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.copy) ByteBuffer(java.nio.ByteBuffer) IgniteFutureCancelledCheckedException(org.apache.ignite.internal.IgniteFutureCancelledCheckedException) BooleanSupplier(java.util.function.BooleanSupplier) FileIO(org.apache.ignite.internal.processors.cache.persistence.file.FileIO) Map(java.util.Map) GridDhtPartitionState(org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtPartitionState) AtomicIntegerArray(java.util.concurrent.atomic.AtomicIntegerArray) ReadWriteLock(java.util.concurrent.locks.ReadWriteLock) GridToStringExclude(org.apache.ignite.internal.util.tostring.GridToStringExclude) Collection(java.util.Collection) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Set(java.util.Set) PageWriteListener(org.apache.ignite.internal.pagemem.store.PageWriteListener) FilePageStoreManager(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager) MetaStorage(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage) UUID(java.util.UUID) Collectors(java.util.stream.Collectors) INDEX_PARTITION(org.apache.ignite.internal.pagemem.PageIdAllocator.INDEX_PARTITION) Objects(java.util.Objects) ByteOrder(java.nio.ByteOrder) Nullable(org.jetbrains.annotations.Nullable) List(java.util.List) FastCrc(org.apache.ignite.internal.processors.cache.persistence.wal.crc.FastCrc) PageIdUtils(org.apache.ignite.internal.pagemem.PageIdUtils) CU(org.apache.ignite.internal.util.typedef.internal.CU) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) CopyOnWriteArrayList(java.util.concurrent.CopyOnWriteArrayList) IgniteThrowableRunner(org.apache.ignite.internal.util.lang.IgniteThrowableRunner) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) U(org.apache.ignite.internal.util.typedef.internal.U) IgniteSnapshotManager.databaseRelativePath(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.databaseRelativePath) HashMap(java.util.HashMap) CompletableFuture(java.util.concurrent.CompletableFuture) ReentrantReadWriteLock(java.util.concurrent.locks.ReentrantReadWriteLock) CacheGroupContext(org.apache.ignite.internal.processors.cache.CacheGroupContext) ArrayList(java.util.ArrayList) HashSet(java.util.HashSet) GridCacheDatabaseSharedManager(org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager) S(org.apache.ignite.internal.util.typedef.internal.S) BiConsumer(java.util.function.BiConsumer) FileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory) PageIO(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO) CheckpointListener(org.apache.ignite.internal.processors.cache.persistence.checkpoint.CheckpointListener) DistributedMetaStorageImpl(org.apache.ignite.internal.processors.metastorage.persistence.DistributedMetaStorageImpl) F(org.apache.ignite.internal.util.typedef.F) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) Iterator(java.util.Iterator) ReentrantLock(java.util.concurrent.locks.ReentrantLock) FilePageStoreManager.cacheWorkDir(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.cacheWorkDir) IOException(java.io.IOException) File(java.io.File) ExecutionException(java.util.concurrent.ExecutionException) GridDhtLocalPartition(org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition) Lock(java.util.concurrent.locks.Lock) IgniteSnapshotManager.partDeltaFile(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.partDeltaFile) BinaryType(org.apache.ignite.binary.BinaryType) GridCacheSharedContext(org.apache.ignite.internal.processors.cache.GridCacheSharedContext) CacheConfiguration(org.apache.ignite.configuration.CacheConfiguration) Closeable(java.io.Closeable) Collections(java.util.Collections) Set(java.util.Set) HashSet(java.util.HashSet) BinaryType(org.apache.ignite.binary.BinaryType) CopyOnWriteArrayList(java.util.concurrent.CopyOnWriteArrayList) ArrayList(java.util.ArrayList) IOException(java.io.IOException) CompletableFuture(java.util.concurrent.CompletableFuture) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Map(java.util.Map) HashMap(java.util.HashMap) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) File(java.io.File) IgniteSnapshotManager.partDeltaFile(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.partDeltaFile) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Example 12 with GroupPartitionId

use of org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId in project ignite by apache.

the class SnapshotResponseRemoteFutureTask method start.

/**
 * {@inheritDoc}
 */
@Override
public boolean start() {
    if (F.isEmpty(parts))
        return false;
    try {
        List<GroupPartitionId> handled = new ArrayList<>();
        for (Map.Entry<Integer, Set<Integer>> e : parts.entrySet()) {
            ofNullable(e.getValue()).orElse(Collections.emptySet()).forEach(p -> handled.add(new GroupPartitionId(e.getKey(), p)));
        }
        snpSndr.init(handled.size());
        File snpDir = cctx.snapshotMgr().snapshotLocalDir(snpName);
        List<CompletableFuture<Void>> futs = new ArrayList<>();
        List<SnapshotMetadata> metas = cctx.snapshotMgr().readSnapshotMetadatas(snpName);
        for (SnapshotMetadata meta : metas) {
            Map<Integer, Set<Integer>> parts0 = meta.partitions();
            if (F.isEmpty(parts0))
                continue;
            handled.removeIf(gp -> {
                if (ofNullable(parts0.get(gp.getGroupId())).orElse(Collections.emptySet()).contains(gp.getPartitionId())) {
                    futs.add(CompletableFuture.runAsync(() -> {
                        if (err.get() != null)
                            return;
                        File cacheDir = cacheDirectory(new File(snpDir, databaseRelativePath(meta.folderName())), gp.getGroupId());
                        if (cacheDir == null) {
                            throw new IgniteException("Cache directory not found [snpName=" + snpName + ", meta=" + meta + ", pair=" + gp + ']');
                        }
                        File snpPart = getPartitionFile(cacheDir.getParentFile(), cacheDir.getName(), gp.getPartitionId());
                        if (!snpPart.exists()) {
                            throw new IgniteException("Snapshot partition file not found [cacheDir=" + cacheDir + ", pair=" + gp + ']');
                        }
                        snpSndr.sendPart(snpPart, cacheDir.getName(), gp, snpPart.length());
                    }, snpSndr.executor()).whenComplete((r, t) -> err.compareAndSet(null, t)));
                    return true;
                }
                return false;
            });
        }
        if (!handled.isEmpty()) {
            err.compareAndSet(null, new IgniteException("Snapshot partitions missed on local node [snpName=" + snpName + ", missed=" + handled + ']'));
        }
        int size = futs.size();
        CompletableFuture.allOf(futs.toArray(new CompletableFuture[size])).whenComplete((r, t) -> {
            Throwable th = ofNullable(err.get()).orElse(t);
            if (th == null && log.isInfoEnabled()) {
                log.info("Snapshot partitions have been sent to the remote node [snpName=" + snpName + ", rmtNodeId=" + srcNodeId + ']');
            }
            close(th);
        });
        return true;
    } catch (Throwable t) {
        if (err.compareAndSet(null, t))
            close(t);
        return false;
    }
}
Also used : F(org.apache.ignite.internal.util.typedef.F) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) Optional.ofNullable(java.util.Optional.ofNullable) IgniteException(org.apache.ignite.IgniteException) Set(java.util.Set) IgniteSnapshotManager.databaseRelativePath(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.databaseRelativePath) CompletableFuture(java.util.concurrent.CompletableFuture) UUID(java.util.UUID) FilePageStoreManager.cacheDirectory(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.cacheDirectory) File(java.io.File) ArrayList(java.util.ArrayList) Nullable(org.jetbrains.annotations.Nullable) List(java.util.List) GridCacheSharedContext(org.apache.ignite.internal.processors.cache.GridCacheSharedContext) Map(java.util.Map) FileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory) Collections(java.util.Collections) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) Set(java.util.Set) ArrayList(java.util.ArrayList) CompletableFuture(java.util.concurrent.CompletableFuture) IgniteException(org.apache.ignite.IgniteException) Map(java.util.Map) File(java.io.File) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Example 13 with GroupPartitionId

use of org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId in project ignite by apache.

the class GridCacheDatabaseSharedManager method reserveHistoryForPreloading.

/**
 * {@inheritDoc}
 */
@Override
public boolean reserveHistoryForPreloading(Map<T2<Integer, Integer>, Long> reservationMap) {
    Map<GroupPartitionId, CheckpointEntry> entries = checkpointHistory().searchCheckpointEntry(reservationMap);
    if (F.isEmpty(entries))
        return false;
    WALPointer oldestWALPointerToReserve = null;
    for (CheckpointEntry cpE : entries.values()) {
        WALPointer ptr = cpE.checkpointMark();
        if (ptr == null)
            return false;
        if (oldestWALPointerToReserve == null || ptr.compareTo(oldestWALPointerToReserve) < 0)
            oldestWALPointerToReserve = ptr;
    }
    if (cctx.wal().reserve(oldestWALPointerToReserve)) {
        reservedForPreloading.set(oldestWALPointerToReserve);
        return true;
    } else
        return false;
}
Also used : CheckpointEntry(org.apache.ignite.internal.processors.cache.persistence.checkpoint.CheckpointEntry) WALPointer(org.apache.ignite.internal.processors.cache.persistence.wal.WALPointer) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Example 14 with GroupPartitionId

use of org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId in project ignite by apache.

the class GridCacheOffheapManager method addPartition.

/**
 * @param part Local partition.
 * @param map Map to add values to.
 * @param metaPageAddr Meta page address
 * @param io Page Meta IO
 * @param grpId Cache Group ID.
 * @param currAllocatedPageCnt total number of pages allocated for partition <code>[partition, grpId]</code>
 */
private static boolean addPartition(GridDhtLocalPartition part, PartitionAllocationMap map, long metaPageAddr, PageMetaIO io, int grpId, int partId, int currAllocatedPageCnt, long partSize) {
    if (part != null) {
        boolean reserved = part.reserve();
        if (!reserved)
            return false;
    } else
        assert partId == PageIdAllocator.INDEX_PARTITION : partId;
    assert PageIO.getPageId(metaPageAddr) != 0;
    int lastAllocatedPageCnt = io.getLastAllocatedPageCount(metaPageAddr);
    int curPageCnt = partSize == 0 ? 0 : currAllocatedPageCnt;
    map.put(new GroupPartitionId(grpId, partId), new PagesAllocationRange(lastAllocatedPageCnt, curPageCnt));
    return true;
}
Also used : PagesAllocationRange(org.apache.ignite.internal.processors.cache.persistence.partstate.PagesAllocationRange) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Example 15 with GroupPartitionId

use of org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId in project ignite by apache.

the class IgniteClusterSnapshotSelfTest method blockingLocalSnapshotSender.

/**
 * @param ignite Ignite instance.
 * @param started Latch will be released when delta partition processing starts.
 * @param blocked Latch to await delta partition processing.
 * @return Factory which produces local snapshot senders.
 */
private Function<String, SnapshotSender> blockingLocalSnapshotSender(IgniteEx ignite, CountDownLatch started, CountDownLatch blocked) {
    Function<String, SnapshotSender> old = snp(ignite).localSnapshotSenderFactory();
    return (snpName) -> new DelegateSnapshotSender(log, snp(ignite).snapshotExecutorService(), old.apply(snpName)) {

        @Override
        public void sendDelta0(File delta, String cacheDirName, GroupPartitionId pair) {
            if (log.isInfoEnabled())
                log.info("Processing delta file has been blocked: " + delta.getName());
            started.countDown();
            try {
                U.await(blocked, TIMEOUT, TimeUnit.MILLISECONDS);
                if (log.isInfoEnabled())
                    log.info("Latch released. Processing delta file continued: " + delta.getName());
                super.sendDelta0(delta, cacheDirName, pair);
            } catch (IgniteInterruptedCheckedException e) {
                throw new IgniteException("Interrupted by node stop", e);
            }
        }
    };
}
Also used : CacheAtomicityMode(org.apache.ignite.cache.CacheAtomicityMode) IgniteInternalFuture(org.apache.ignite.internal.IgniteInternalFuture) DiscoveryCustomEvent(org.apache.ignite.internal.events.DiscoveryCustomEvent) Arrays(java.util.Arrays) EVT_CLUSTER_SNAPSHOT_FINISHED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_FINISHED) SNP_NODE_STOPPING_ERR_MSG(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.SNP_NODE_STOPPING_ERR_MSG) SNAPSHOT_METRICS(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.SNAPSHOT_METRICS) Transaction(org.apache.ignite.transactions.Transaction) GridDhtPartitionsAbstractMessage(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsAbstractMessage) IgniteEx(org.apache.ignite.internal.IgniteEx) GridDhtPartitionSupplyMessage(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyMessage) RendezvousAffinityFunction(org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction) FileIO(org.apache.ignite.internal.processors.cache.persistence.file.FileIO) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) Map(java.util.Map) GridTestUtils.assertThrowsAnyCause(org.apache.ignite.testframework.GridTestUtils.assertThrowsAnyCause) IgniteFuture(org.apache.ignite.lang.IgniteFuture) RandomAccessFileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.RandomAccessFileIOFactory) GridTestUtils.assertThrowsWithCause(org.apache.ignite.testframework.GridTestUtils.assertThrowsWithCause) SingleNodeMessage(org.apache.ignite.internal.util.distributed.SingleNodeMessage) Predicate(java.util.function.Predicate) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) IgniteException(org.apache.ignite.IgniteException) CacheGroupDescriptor(org.apache.ignite.internal.processors.cache.CacheGroupDescriptor) IgniteSnapshotManager.isSnapshotOperation(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.isSnapshotOperation) UUID(java.util.UUID) IgniteCache(org.apache.ignite.IgniteCache) Serializable(java.io.Serializable) GridTestUtils(org.apache.ignite.testframework.GridTestUtils) CountDownLatch(java.util.concurrent.CountDownLatch) ObjectGauge(org.apache.ignite.internal.processors.metric.impl.ObjectGauge) List(java.util.List) IgniteConfiguration(org.apache.ignite.configuration.IgniteConfiguration) GridDhtPartitionDemandMessage(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionDemandMessage) CU(org.apache.ignite.internal.util.typedef.internal.CU) GridCacheRebalancingSyncSelfTest.checkPartitionMapExchangeFinished(org.apache.ignite.internal.processors.cache.distributed.rebalancing.GridCacheRebalancingSyncSelfTest.checkPartitionMapExchangeFinished) Queue(java.util.Queue) TestRecordingCommunicationSpi(org.apache.ignite.internal.TestRecordingCommunicationSpi) ScanQuery(org.apache.ignite.cache.query.ScanQuery) ConcurrentLinkedQueue(java.util.concurrent.ConcurrentLinkedQueue) NodeStoppingException(org.apache.ignite.internal.NodeStoppingException) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) U(org.apache.ignite.internal.util.typedef.internal.U) EVT_DISCOVERY_CUSTOM_EVT(org.apache.ignite.internal.events.DiscoveryCustomEvent.EVT_DISCOVERY_CUSTOM_EVT) IgniteSnapshotManager.resolveSnapshotWorkDirectory(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.resolveSnapshotWorkDirectory) HashMap(java.util.HashMap) Callable(java.util.concurrent.Callable) ClusterTopologyException(org.apache.ignite.cluster.ClusterTopologyException) EVT_CLUSTER_SNAPSHOT_STARTED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_STARTED) Function(java.util.function.Function) EVT_CLUSTER_SNAPSHOT_FAILED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_FAILED) SNP_IN_PROGRESS_ERR_MSG(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager.SNP_IN_PROGRESS_ERR_MSG) DiscoveryCustomMessage(org.apache.ignite.internal.managers.discovery.DiscoveryCustomMessage) GridDhtPartitionsExchangeFuture(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture) ThreadLocalRandom(java.util.concurrent.ThreadLocalRandom) FileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory) IgniteInterruptedCheckedException(org.apache.ignite.internal.IgniteInterruptedCheckedException) Before(org.junit.Before) G(org.apache.ignite.internal.util.typedef.G) ACTIVE(org.apache.ignite.cluster.ClusterState.ACTIVE) DistributedProcess(org.apache.ignite.internal.util.distributed.DistributedProcess) EVTS_CLUSTER_SNAPSHOT(org.apache.ignite.events.EventType.EVTS_CLUSTER_SNAPSHOT) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) OpenOption(java.nio.file.OpenOption) IOException(java.io.IOException) Test(org.junit.Test) Ignite(org.apache.ignite.Ignite) GridDhtPartitionsSingleMessage(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsSingleMessage) MetricRegistry(org.apache.ignite.internal.processors.metric.MetricRegistry) FullMessage(org.apache.ignite.internal.util.distributed.FullMessage) File(java.io.File) T2(org.apache.ignite.internal.util.typedef.T2) TimeUnit(java.util.concurrent.TimeUnit) PartitionsExchangeAware(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.PartitionsExchangeAware) Ignition(org.apache.ignite.Ignition) CacheConfiguration(org.apache.ignite.configuration.CacheConfiguration) GridDhtPartitionExchangeId(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionExchangeId) LongMetric(org.apache.ignite.spi.metric.LongMetric) Collections(java.util.Collections) IgniteInterruptedCheckedException(org.apache.ignite.internal.IgniteInterruptedCheckedException) IgniteException(org.apache.ignite.IgniteException) File(java.io.File) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Aggregations

GroupPartitionId (org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)19 Map (java.util.Map)10 IgniteException (org.apache.ignite.IgniteException)10 File (java.io.File)9 HashMap (java.util.HashMap)9 Set (java.util.Set)7 UUID (java.util.UUID)7 IgniteCheckedException (org.apache.ignite.IgniteCheckedException)7 IgniteEx (org.apache.ignite.internal.IgniteEx)7 HashSet (java.util.HashSet)6 Test (org.junit.Test)6 ArrayList (java.util.ArrayList)5 Collections (java.util.Collections)5 List (java.util.List)5 CountDownLatch (java.util.concurrent.CountDownLatch)5 AtomicInteger (java.util.concurrent.atomic.AtomicInteger)5 IgniteInterruptedCheckedException (org.apache.ignite.internal.IgniteInterruptedCheckedException)5 ConcurrentHashMap (java.util.concurrent.ConcurrentHashMap)4 IgniteInternalFuture (org.apache.ignite.internal.IgniteInternalFuture)4 GridCacheSharedContext (org.apache.ignite.internal.processors.cache.GridCacheSharedContext)4