Search in sources :

Example 6 with GroupPartitionId

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

the class GridCacheProcessor method toStringTopProcessingPartitions.

/**
 * Creation of a string representation of the top (descending) partitions, the processing of which took the most time.
 *
 * @param top Top (ascending) processed partitions.
 * @param groups Cache group contexts.
 * @return String representation.
 */
static String toStringTopProcessingPartitions(SortedSet<T3<Long, Long, GroupPartitionId>> top, Collection<CacheGroupContext> groups) {
    if (top.isEmpty())
        return "[]";
    StringJoiner sj0 = new StringJoiner(", ", "[", "]");
    TreeMap<Long, List<GroupPartitionId>> top0 = top.stream().collect(groupingBy(T3::get1, TreeMap::new, mapping(T3::get3, toList())));
    for (Map.Entry<Long, List<GroupPartitionId>> e0 : top0.descendingMap().entrySet()) {
        Map<Integer, List<GroupPartitionId>> byCacheGrpId = e0.getValue().stream().collect(groupingBy(GroupPartitionId::getGroupId));
        StringJoiner sj1 = new StringJoiner(", ", "[", "]");
        for (Map.Entry<Integer, List<GroupPartitionId>> e1 : byCacheGrpId.entrySet()) {
            @Nullable CacheGroupContext grp = groups.stream().filter(g -> g.groupId() == e1.getKey()).findAny().orElse(null);
            String parts = e1.getValue().stream().map(GroupPartitionId::getPartitionId).sorted().map(p -> grp == null ? p.toString() : p + ":" + grp.topology().localPartition(p).fullSize()).collect(Collectors.joining(", ", "[", "]"));
            sj1.add("[grp=" + (grp == null ? e1.getKey() : grp.cacheOrGroupName()) + ", part=" + parts + ']');
        }
        sj0.add("[time=" + U.humanReadableDuration(e0.getKey()) + ' ' + sj1.toString() + ']');
    }
    return sj0.toString();
}
Also used : SchemaAbstractDiscoveryMessage(org.apache.ignite.internal.processors.query.schema.message.SchemaAbstractDiscoveryMessage) GridFinishedFuture(org.apache.ignite.internal.util.future.GridFinishedFuture) ValidationOnNodeJoinUtils.validateHashIdResolvers(org.apache.ignite.internal.processors.cache.ValidationOnNodeJoinUtils.validateHashIdResolvers) GridCacheUtils.isPersistentCache(org.apache.ignite.internal.processors.cache.GridCacheUtils.isPersistentCache) MetastorageLifecycleListener(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetastorageLifecycleListener) ReadOnlyMetastorage(org.apache.ignite.internal.processors.cache.persistence.metastorage.ReadOnlyMetastorage) PagesList(org.apache.ignite.internal.processors.cache.persistence.freelist.PagesList) GridDhtAtomicCache(org.apache.ignite.internal.processors.cache.distributed.dht.atomic.GridDhtAtomicCache) Arrays.asList(java.util.Arrays.asList) Map(java.util.Map) AffinityFunction(org.apache.ignite.cache.affinity.AffinityFunction) CachePagesListView(org.apache.ignite.spi.systemview.view.CachePagesListView) AffinityFunctionContext(org.apache.ignite.cache.affinity.AffinityFunctionContext) GridIoPolicy(org.apache.ignite.internal.managers.communication.GridIoPolicy) Objects.isNull(java.util.Objects.isNull) CacheStore(org.apache.ignite.cache.store.CacheStore) InitializationProtector(org.apache.ignite.internal.util.InitializationProtector) IgniteInClosure(org.apache.ignite.lang.IgniteInClosure) ChangeGlobalStateFinishMessage(org.apache.ignite.internal.processors.cluster.ChangeGlobalStateFinishMessage) CountDownLatch(java.util.concurrent.CountDownLatch) SnapshotDiscoveryMessage(org.apache.ignite.internal.processors.cache.persistence.snapshot.SnapshotDiscoveryMessage) EternalExpiryPolicy(javax.cache.expiry.EternalExpiryPolicy) RowStore(org.apache.ignite.internal.processors.cache.persistence.RowStore) Stream(java.util.stream.Stream) IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK(org.apache.ignite.IgniteSystemProperties.IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK) IgniteWriteAheadLogManager(org.apache.ignite.internal.pagemem.wal.IgniteWriteAheadLogManager) SecurityUtils.remoteSecurityContext(org.apache.ignite.internal.processors.security.SecurityUtils.remoteSecurityContext) IoStatisticsType(org.apache.ignite.internal.metric.IoStatisticsType) U(org.apache.ignite.internal.util.typedef.internal.U) IgniteOutClosureX(org.apache.ignite.internal.util.lang.IgniteOutClosureX) SecurityPermission(org.apache.ignite.plugin.security.SecurityPermission) IgniteDiscoverySpi(org.apache.ignite.internal.managers.discovery.IgniteDiscoverySpi) GridCacheDatabaseSharedManager(org.apache.ignite.internal.processors.cache.persistence.GridCacheDatabaseSharedManager) F0(org.apache.ignite.internal.util.F0) S(org.apache.ignite.internal.util.typedef.internal.S) GridCacheDistributedQueryManager(org.apache.ignite.internal.processors.cache.query.GridCacheDistributedQueryManager) PartitionStateViewWalker(org.apache.ignite.internal.managers.systemview.walker.PartitionStateViewWalker) A(org.apache.ignite.internal.util.typedef.internal.A) MetricRegistry(org.apache.ignite.internal.processors.metric.MetricRegistry) T3(org.apache.ignite.internal.util.typedef.T3) T2(org.apache.ignite.internal.util.typedef.T2) REPLICATED(org.apache.ignite.cache.CacheMode.REPLICATED) CacheJtaManagerAdapter(org.apache.ignite.internal.processors.cache.jta.CacheJtaManagerAdapter) GridDiscoveryData(org.apache.ignite.spi.discovery.DiscoveryDataBag.GridDiscoveryData) TreeMap(java.util.TreeMap) GridCacheLocalQueryManager(org.apache.ignite.internal.processors.cache.query.GridCacheLocalQueryManager) CacheConfiguration(org.apache.ignite.configuration.CacheConfiguration) CacheGroupIoViewWalker(org.apache.ignite.internal.managers.systemview.walker.CacheGroupIoViewWalker) IgniteCacheSnapshotManager(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteCacheSnapshotManager) GridPerformanceSuggestions(org.apache.ignite.internal.suggestions.GridPerformanceSuggestions) GridDhtCache(org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCache) DatabaseLifecycleListener(org.apache.ignite.internal.processors.cache.persistence.DatabaseLifecycleListener) CacheMode(org.apache.ignite.cache.CacheMode) IgniteInternalFuture(org.apache.ignite.internal.IgniteInternalFuture) IgniteSystemProperties.getBoolean(org.apache.ignite.IgniteSystemProperties.getBoolean) DataRegion(org.apache.ignite.internal.processors.cache.persistence.DataRegion) SortedSet(java.util.SortedSet) ListIterator(java.util.ListIterator) GridCacheQueryManager(org.apache.ignite.internal.processors.cache.query.GridCacheQueryManager) PartitionDefferedDeleteQueueCleanupTask(org.apache.ignite.internal.processors.cache.distributed.dht.topology.PartitionDefferedDeleteQueueCleanupTask) SchemaExchangeWorkerTask(org.apache.ignite.internal.processors.query.schema.SchemaExchangeWorkerTask) StopCachesOnClientReconnectExchangeTask(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.StopCachesOnClientReconnectExchangeTask) QueryEntity(org.apache.ignite.cache.QueryEntity) PartitionsEvictManager(org.apache.ignite.internal.processors.cache.distributed.dht.topology.PartitionsEvictManager) IgniteMBeanAware(org.apache.ignite.mxbean.IgniteMBeanAware) IgniteOutClosure(org.apache.ignite.lang.IgniteOutClosure) Collection(java.util.Collection) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) MetaStorage(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage) UUID(java.util.UUID) Collectors(java.util.stream.Collectors) WarmUpConfiguration(org.apache.ignite.configuration.WarmUpConfiguration) IgniteBiTuple(org.apache.ignite.lang.IgniteBiTuple) Nullable(org.jetbrains.annotations.Nullable) DataStructuresProcessor(org.apache.ignite.internal.processors.datastructures.DataStructuresProcessor) CU(org.apache.ignite.internal.util.typedef.internal.CU) Objects.nonNull(java.util.Objects.nonNull) IntStream(java.util.stream.IntStream) FileWriteAheadLogManager(org.apache.ignite.internal.processors.cache.persistence.wal.FileWriteAheadLogManager) MarshallerUtils(org.apache.ignite.marshaller.MarshallerUtils) GridNearTransactionalCache(org.apache.ignite.internal.processors.cache.distributed.near.GridNearTransactionalCache) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) IgniteFeatures(org.apache.ignite.internal.IgniteFeatures) Function(java.util.function.Function) NearCacheConfiguration(org.apache.ignite.configuration.NearCacheConfiguration) ConcurrentMap(java.util.concurrent.ConcurrentMap) HashSet(java.util.HashSet) SchemaNodeLeaveExchangeWorkerTask(org.apache.ignite.internal.processors.query.schema.SchemaNodeLeaveExchangeWorkerTask) IgniteClosure(org.apache.ignite.lang.IgniteClosure) IgnitePredicate(org.apache.ignite.lang.IgnitePredicate) MBeanServer(javax.management.MBeanServer) Collectors.mapping(java.util.stream.Collectors.mapping) DataStorageConfiguration(org.apache.ignite.configuration.DataStorageConfiguration) PlatformCacheManager(org.apache.ignite.internal.processors.platform.cache.PlatformCacheManager) IgniteSecurity(org.apache.ignite.internal.processors.security.IgniteSecurity) ExecutorService(java.util.concurrent.ExecutorService) SHARED(org.apache.ignite.configuration.DeploymentMode.SHARED) JTA(org.apache.ignite.internal.IgniteComponentType.JTA) GridLocalAtomicCache(org.apache.ignite.internal.processors.cache.local.atomic.GridLocalAtomicCache) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) QuerySchemaPatch(org.apache.ignite.internal.processors.query.QuerySchemaPatch) GridAffinityAssignmentCache(org.apache.ignite.internal.processors.affinity.GridAffinityAssignmentCache) GridPlainClosure2(org.apache.ignite.internal.util.lang.GridPlainClosure2) Collectors.toList(java.util.stream.Collectors.toList) DiscoveryDataClusterState(org.apache.ignite.internal.processors.cluster.DiscoveryDataClusterState) StringJoiner(java.util.StringJoiner) IgniteTransactionsEx(org.apache.ignite.internal.IgniteTransactionsEx) ATOMIC(org.apache.ignite.cache.CacheAtomicityMode.ATOMIC) Comparator(java.util.Comparator) DataRegionConfiguration(org.apache.ignite.configuration.DataRegionConfiguration) GridFutureAdapter(org.apache.ignite.internal.util.future.GridFutureAdapter) QueryUtils(org.apache.ignite.internal.processors.query.QueryUtils) SYNC(org.apache.ignite.cache.CacheRebalanceMode.SYNC) IgniteCacheObjectProcessor(org.apache.ignite.internal.processors.cacheobject.IgniteCacheObjectProcessor) GridCacheUtils.isNearEnabled(org.apache.ignite.internal.processors.cache.GridCacheUtils.isNearEnabled) DeadlockDetectionManager(org.apache.ignite.internal.processors.cache.mvcc.DeadlockDetectionManager) GridDhtColocatedCache(org.apache.ignite.internal.processors.cache.distributed.dht.colocated.GridDhtColocatedCache) ReuseList(org.apache.ignite.internal.processors.cache.persistence.tree.reuse.ReuseList) FinishPreloadingTask(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.FinishPreloadingTask) QuerySchema(org.apache.ignite.internal.processors.query.QuerySchema) LOCAL(org.apache.ignite.cache.CacheMode.LOCAL) BinaryContext(org.apache.ignite.internal.binary.BinaryContext) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Set(java.util.Set) IgniteCollectors(org.apache.ignite.internal.util.IgniteCollectors) IgniteClusterReadOnlyException(org.apache.ignite.internal.processors.cache.distributed.dht.IgniteClusterReadOnlyException) IgnitePageStoreManager(org.apache.ignite.internal.pagemem.store.IgnitePageStoreManager) FreeList(org.apache.ignite.internal.processors.cache.persistence.freelist.FreeList) ClusterState(org.apache.ignite.cluster.ClusterState) Collectors.groupingBy(java.util.stream.Collectors.groupingBy) GridCompoundFuture(org.apache.ignite.internal.util.future.GridCompoundFuture) TreeSet(java.util.TreeSet) GridBinaryMarshaller(org.apache.ignite.internal.binary.GridBinaryMarshaller) ArrayList(java.util.ArrayList) GridKernalContext(org.apache.ignite.internal.GridKernalContext) GridCacheOffheapManager(org.apache.ignite.internal.processors.cache.persistence.GridCacheOffheapManager) IgniteTransactionsImpl(org.apache.ignite.internal.processors.cache.transactions.IgniteTransactionsImpl) ClusterNode(org.apache.ignite.cluster.ClusterNode) DiscoveryCustomMessage(org.apache.ignite.internal.managers.discovery.DiscoveryCustomMessage) IgniteInterruptedException(org.apache.ignite.IgniteInterruptedException) IgniteInterruptedCheckedException(org.apache.ignite.internal.IgniteInterruptedCheckedException) CheckpointListener(org.apache.ignite.internal.processors.cache.persistence.checkpoint.CheckpointListener) CacheStoreManager(org.apache.ignite.internal.processors.cache.store.CacheStoreManager) IgniteTxManager(org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager) GridCacheDrManager(org.apache.ignite.internal.processors.cache.dr.GridCacheDrManager) ExpiryPolicy(javax.cache.expiry.ExpiryPolicy) AtomicLongFieldUpdater(java.util.concurrent.atomic.AtomicLongFieldUpdater) IgniteSnapshotManager(org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager) CacheGroupIoView(org.apache.ignite.spi.systemview.view.CacheGroupIoView) Marshaller(org.apache.ignite.marshaller.Marshaller) WarmUpStrategy(org.apache.ignite.internal.processors.cache.warmup.WarmUpStrategy) DetachedClusterNode(org.apache.ignite.internal.cluster.DetachedClusterNode) GridDhtCacheAdapter(org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter) GridCacheVersionManager(org.apache.ignite.internal.processors.cache.version.GridCacheVersionManager) CachePluginManager(org.apache.ignite.internal.processors.plugin.CachePluginManager) CACHE_PROC(org.apache.ignite.internal.GridComponent.DiscoveryDataExchangeType.CACHE_PROC) CachePagesListViewWalker(org.apache.ignite.internal.managers.systemview.walker.CachePagesListViewWalker) GridProcessorAdapter(org.apache.ignite.internal.processors.GridProcessorAdapter) GridLocalCache(org.apache.ignite.internal.processors.cache.local.GridLocalCache) IgniteUuid(org.apache.ignite.lang.IgniteUuid) BinaryMarshaller(org.apache.ignite.internal.binary.BinaryMarshaller) LifecycleAware(org.apache.ignite.lifecycle.LifecycleAware) DiscoveryDataBag(org.apache.ignite.spi.discovery.DiscoveryDataBag) JoiningNodeDiscoveryData(org.apache.ignite.spi.discovery.DiscoveryDataBag.JoiningNodeDiscoveryData) CacheGroupMetricsMXBean(org.apache.ignite.mxbean.CacheGroupMetricsMXBean) CacheContinuousQueryManager(org.apache.ignite.internal.processors.cache.query.continuous.CacheContinuousQueryManager) TRANSACTIONAL_SNAPSHOT(org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL_SNAPSHOT) CacheStoreSessionListener(org.apache.ignite.cache.store.CacheStoreSessionListener) DFLT_CACHE_REMOVE_ENTRIES_TTL(org.apache.ignite.internal.processors.cache.distributed.dht.topology.GridDhtLocalPartition.DFLT_CACHE_REMOVE_ENTRIES_TTL) IgniteSystemProperties(org.apache.ignite.IgniteSystemProperties) X(org.apache.ignite.internal.util.typedef.X) DeploymentMode(org.apache.ignite.configuration.DeploymentMode) PARTITIONED(org.apache.ignite.cache.CacheMode.PARTITIONED) SecurityException(org.apache.ignite.plugin.security.SecurityException) MetricUtils.metricName(org.apache.ignite.internal.processors.metric.impl.MetricUtils.metricName) MvccCachingManager(org.apache.ignite.internal.processors.cache.mvcc.MvccCachingManager) Collectors.toSet(java.util.stream.Collectors.toSet) IgniteFuture(org.apache.ignite.lang.IgniteFuture) IdentityHashMap(java.util.IdentityHashMap) IgniteClientDisconnectedCheckedException(org.apache.ignite.internal.IgniteClientDisconnectedCheckedException) EventType(org.apache.ignite.events.EventType) PartitionStateView(org.apache.ignite.spi.systemview.view.PartitionStateView) IgniteException(org.apache.ignite.IgniteException) FilePageStoreManager(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager) String.format(java.lang.String.format) GridNearAtomicCache(org.apache.ignite.internal.processors.cache.distributed.near.GridNearAtomicCache) List(java.util.List) IGNITE_CACHE_REMOVED_ENTRIES_TTL(org.apache.ignite.IgniteSystemProperties.IGNITE_CACHE_REMOVED_ENTRIES_TTL) Optional(java.util.Optional) NotNull(org.jetbrains.annotations.NotNull) HashMap(java.util.HashMap) CONTINUOUS(org.apache.ignite.configuration.DeploymentMode.CONTINUOUS) CacheExistsException(org.apache.ignite.cache.CacheExistsException) AtomicReference(java.util.concurrent.atomic.AtomicReference) CacheDataStructuresManager(org.apache.ignite.internal.processors.cache.datastructures.CacheDataStructuresManager) IgniteNodeValidationResult(org.apache.ignite.spi.IgniteNodeValidationResult) IgniteUtils.doInParallel(org.apache.ignite.internal.util.IgniteUtils.doInParallel) CacheException(javax.cache.CacheException) IgniteThrowableFunction(org.apache.ignite.internal.util.lang.IgniteThrowableFunction) F(org.apache.ignite.internal.util.typedef.F) SchemaProposeDiscoveryMessage(org.apache.ignite.internal.processors.query.schema.message.SchemaProposeDiscoveryMessage) Iterator(java.util.Iterator) AffinityTopologyVersion(org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion) ClusterTopologyCheckedException(org.apache.ignite.internal.cluster.ClusterTopologyCheckedException) FULL_SYNC(org.apache.ignite.cache.CacheWriteSynchronizationMode.FULL_SYNC) CacheObjectBinaryProcessorImpl(org.apache.ignite.internal.processors.cache.binary.CacheObjectBinaryProcessorImpl) GridToStringInclude(org.apache.ignite.internal.util.tostring.GridToStringInclude) TimeUnit(java.util.concurrent.TimeUnit) IgniteCacheDatabaseSharedManager(org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager) ChangeGlobalStateMessage(org.apache.ignite.internal.processors.cluster.ChangeGlobalStateMessage) Collections(java.util.Collections) PagesList(org.apache.ignite.internal.processors.cache.persistence.freelist.PagesList) Arrays.asList(java.util.Arrays.asList) Collectors.toList(java.util.stream.Collectors.toList) ReuseList(org.apache.ignite.internal.processors.cache.persistence.tree.reuse.ReuseList) FreeList(org.apache.ignite.internal.processors.cache.persistence.freelist.FreeList) ArrayList(java.util.ArrayList) List(java.util.List) Map(java.util.Map) TreeMap(java.util.TreeMap) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) ConcurrentMap(java.util.concurrent.ConcurrentMap) IdentityHashMap(java.util.IdentityHashMap) HashMap(java.util.HashMap) StringJoiner(java.util.StringJoiner) Nullable(org.jetbrains.annotations.Nullable) T3(org.apache.ignite.internal.util.typedef.T3)

Example 7 with GroupPartitionId

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

the class SnapshotFutureTask method addPartitionWriters.

/**
 * @param grpId Cache group id.
 * @param parts Set of partitions to be processed.
 * @param dirName Directory name to init.
 * @throws IgniteCheckedException If fails.
 */
private void addPartitionWriters(int grpId, Set<Integer> parts, String dirName) throws IgniteCheckedException {
    Integer encGrpId = cctx.cache().isEncrypted(grpId) ? grpId : null;
    for (int partId : parts) {
        GroupPartitionId pair = new GroupPartitionId(grpId, partId);
        PageStore store = pageStore.getStore(grpId, partId);
        partDeltaWriters.put(pair, new PageStoreSerialWriter(store, partDeltaFile(cacheWorkDir(tmpConsIdDir, dirName), partId), encGrpId));
        partFileLengths.put(pair, store.size());
    }
}
Also used : PageStore(org.apache.ignite.internal.pagemem.store.PageStore) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId)

Example 8 with GroupPartitionId

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

the class IgniteSnapshotManagerSelfTest method testLocalSnapshotOnCacheStopped.

/**
 * @throws Exception If fails.
 */
@Test(expected = IgniteCheckedException.class)
public void testLocalSnapshotOnCacheStopped() throws Exception {
    IgniteEx ig = startGridWithCache(dfltCacheCfg, CACHE_KEYS_RANGE);
    startGrid(1);
    ig.cluster().state(ClusterState.ACTIVE);
    awaitPartitionMapExchange();
    GridCacheSharedContext<?, ?> cctx0 = ig.context().cache().context();
    IgniteSnapshotManager mgr = snp(ig);
    CountDownLatch cpLatch = new CountDownLatch(1);
    IgniteInternalFuture<?> snpFut = startLocalSnapshotTask(cctx0, SNAPSHOT_NAME, F.asMap(CU.cacheId(DEFAULT_CACHE_NAME), null), encryption, new DelegateSnapshotSender(log, mgr.snapshotExecutorService(), mgr.localSnapshotSenderFactory().apply(SNAPSHOT_NAME)) {

        @Override
        public void sendPart0(File part, String cacheDirName, GroupPartitionId pair, Long length) {
            try {
                U.await(cpLatch);
                delegate.sendPart0(part, cacheDirName, pair, length);
            } catch (IgniteInterruptedCheckedException e) {
                throw new IgniteException(e);
            }
        }
    });
    IgniteCache<?, ?> cache = ig.getOrCreateCache(DEFAULT_CACHE_NAME);
    cache.destroy();
    cpLatch.countDown();
    snpFut.get(5_000, TimeUnit.MILLISECONDS);
}
Also used : CountDownLatch(java.util.concurrent.CountDownLatch) IgniteInterruptedCheckedException(org.apache.ignite.internal.IgniteInterruptedCheckedException) IgniteException(org.apache.ignite.IgniteException) IgniteEx(org.apache.ignite.internal.IgniteEx) File(java.io.File) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) Test(org.junit.Test)

Example 9 with GroupPartitionId

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

the class IgniteSnapshotRestoreFromRemoteTest method testSnapshotCachesStoppedIfLoadingFailOnRemote.

/**
 * @throws Exception If failed.
 */
@Test
public void testSnapshotCachesStoppedIfLoadingFailOnRemote() throws Exception {
    IgniteEx scc = startDedicatedGrids(SECOND_CLUSTER_PREFIX, 2);
    scc.cluster().state(ClusterState.ACTIVE);
    copyAndShuffle(snpParts, G.allGrids());
    grid(0).cache(DEFAULT_CACHE_NAME).destroy();
    IgniteSnapshotManager mgr = snp(grid(1));
    mgr.remoteSnapshotSenderFactory(new BiFunction<String, UUID, SnapshotSender>() {

        @Override
        public SnapshotSender apply(String s, UUID uuid) {
            return new DelegateSnapshotSender(log, mgr.snapshotExecutorService(), mgr.remoteSnapshotSenderFactory(s, uuid)) {

                @Override
                public void sendPart0(File part, String cacheDirName, GroupPartitionId pair, Long length) {
                    if (partId(part.getName()) > 0)
                        throw new IgniteException("Test exception. Uploading partition file failed: " + pair);
                    super.sendPart0(part, cacheDirName, pair, length);
                }
            };
        }
    });
    IgniteFuture<?> fut = grid(0).snapshot().restoreSnapshot(SNAPSHOT_NAME, null);
    GridTestUtils.assertThrowsAnyCause(log, () -> fut.get(TIMEOUT), IgniteException.class, "Test exception. Uploading partition file failed");
    assertNull(scc.cache(DEFAULT_CACHE_NAME));
    ensureCacheAbsent(dfltCacheCfg);
}
Also used : IgniteException(org.apache.ignite.IgniteException) IgniteEx(org.apache.ignite.internal.IgniteEx) UUID(java.util.UUID) File(java.io.File) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) Test(org.junit.Test)

Example 10 with GroupPartitionId

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

the class IgniteSnapshotManager method initLocalSnapshotStartStage.

/**
 * @param req Request on snapshot creation.
 * @return Future which will be completed when a snapshot has been started.
 */
private IgniteInternalFuture<SnapshotOperationResponse> initLocalSnapshotStartStage(SnapshotOperationRequest req) {
    if (cctx.kernalContext().clientNode() || !CU.baselineNode(cctx.localNode(), cctx.kernalContext().state().clusterState()))
        return new GridFinishedFuture<>();
    // so it is safe to set new snapshot task inside this method without synchronization.
    if (clusterSnpReq != null) {
        return new GridFinishedFuture<>(new IgniteCheckedException("Snapshot operation has been rejected. " + "Another snapshot operation in progress [req=" + req + ", curr=" + clusterSnpReq + ']'));
    }
    Set<UUID> leftNodes = new HashSet<>(req.nodes());
    leftNodes.removeAll(F.viewReadOnly(cctx.discovery().serverNodes(AffinityTopologyVersion.NONE), F.node2id()));
    if (!leftNodes.isEmpty()) {
        return new GridFinishedFuture<>(new IgniteCheckedException("Some of baseline nodes left the cluster " + "prior to snapshot operation start: " + leftNodes));
    }
    if (!cctx.localNode().isClient() && cctx.kernalContext().encryption().isMasterKeyChangeInProgress()) {
        return new GridFinishedFuture<>(new IgniteCheckedException("Snapshot operation has been rejected. Master " + "key changing process is not finished yet."));
    }
    if (!cctx.localNode().isClient() && cctx.kernalContext().encryption().reencryptionInProgress()) {
        return new GridFinishedFuture<>(new IgniteCheckedException("Snapshot operation has been rejected. Caches " + "re-encryption process is not finished yet."));
    }
    List<Integer> grpIds = new ArrayList<>(F.viewReadOnly(req.groups(), CU::cacheId));
    Set<Integer> leftGrps = new HashSet<>(grpIds);
    leftGrps.removeAll(cctx.cache().cacheGroupDescriptors().keySet());
    boolean withMetaStorage = leftGrps.remove(METASTORAGE_CACHE_ID);
    if (!leftGrps.isEmpty()) {
        return new GridFinishedFuture<>(new IgniteCheckedException("Some of requested cache groups doesn't exist " + "on the local node [missed=" + leftGrps + ", nodeId=" + cctx.localNodeId() + ']'));
    }
    Map<Integer, Set<Integer>> parts = new HashMap<>();
    // Cache group context may be 'null' on some nodes e.g. a node filter is set.
    for (Integer grpId : grpIds) {
        if (cctx.cache().cacheGroup(grpId) == null)
            continue;
        parts.put(grpId, null);
    }
    IgniteInternalFuture<?> task0;
    if (parts.isEmpty() && !withMetaStorage)
        task0 = new GridFinishedFuture<>(Collections.emptySet());
    else {
        task0 = registerSnapshotTask(req.snapshotName(), req.operationalNodeId(), parts, withMetaStorage, locSndrFactory.apply(req.snapshotName()));
        if (withMetaStorage && task0 instanceof SnapshotFutureTask) {
            ((DistributedMetaStorageImpl) cctx.kernalContext().distributedMetastorage()).suspend(((SnapshotFutureTask) task0).started());
        }
        clusterSnpReq = req;
    }
    return task0.chain(fut -> {
        if (fut.error() != null)
            throw F.wrap(fut.error());
        try {
            Set<String> blts = req.nodes().stream().map(n -> cctx.discovery().node(n).consistentId().toString()).collect(Collectors.toSet());
            File smf = new File(snapshotLocalDir(req.snapshotName()), snapshotMetaFileName(cctx.localNode().consistentId().toString()));
            if (smf.exists())
                throw new GridClosureException(new IgniteException("Snapshot metafile must not exist: " + smf.getAbsolutePath()));
            smf.getParentFile().mkdirs();
            SnapshotMetadata meta = new SnapshotMetadata(req.requestId(), req.snapshotName(), cctx.localNode().consistentId().toString(), pdsSettings.folderName(), cctx.gridConfig().getDataStorageConfiguration().getPageSize(), grpIds, blts, (Set<GroupPartitionId>) fut.result());
            try (OutputStream out = new BufferedOutputStream(new FileOutputStream(smf))) {
                U.marshal(marsh, meta, out);
                log.info("Snapshot metafile has been created: " + smf.getAbsolutePath());
            }
            SnapshotHandlerContext ctx = new SnapshotHandlerContext(meta, req.groups(), cctx.localNode());
            return new SnapshotOperationResponse(handlers.invokeAll(SnapshotHandlerType.CREATE, ctx));
        } catch (IOException | IgniteCheckedException e) {
            throw F.wrap(e);
        }
    });
}
Also used : MappedName(org.apache.ignite.internal.processors.marshaller.MappedName) EVT_CLUSTER_SNAPSHOT_FINISHED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_FINISHED) BufferedInputStream(java.io.BufferedInputStream) GridFinishedFuture(org.apache.ignite.internal.util.future.GridFinishedFuture) MetastorageLifecycleListener(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetastorageLifecycleListener) CacheObjectBinaryProcessorImpl.binaryWorkDir(org.apache.ignite.internal.processors.cache.binary.CacheObjectBinaryProcessorImpl.binaryWorkDir) ReadOnlyMetastorage(org.apache.ignite.internal.processors.cache.persistence.metastorage.ReadOnlyMetastorage) FileIO(org.apache.ignite.internal.processors.cache.persistence.file.FileIO) METASTORAGE_CACHE_ID(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage.METASTORAGE_CACHE_ID) Map(java.util.Map) TransmissionHandler(org.apache.ignite.internal.managers.communication.TransmissionHandler) Path(java.nio.file.Path) GridToStringExclude(org.apache.ignite.internal.util.tostring.GridToStringExclude) CacheGroupDescriptor(org.apache.ignite.internal.processors.cache.CacheGroupDescriptor) CacheDataRow(org.apache.ignite.internal.processors.cache.persistence.CacheDataRow) Serializable(java.io.Serializable) ByteOrder(java.nio.ByteOrder) FileVisitResult(java.nio.file.FileVisitResult) SnapshotEvent(org.apache.ignite.events.SnapshotEvent) END_SNAPSHOT(org.apache.ignite.internal.util.distributed.DistributedProcess.DistributedProcessType.END_SNAPSHOT) IgniteFutureImpl(org.apache.ignite.internal.util.future.IgniteFutureImpl) U(org.apache.ignite.internal.util.typedef.internal.U) EVT_DISCOVERY_CUSTOM_EVT(org.apache.ignite.internal.events.DiscoveryCustomEvent.EVT_DISCOVERY_CUSTOM_EVT) IgniteLogger(org.apache.ignite.IgniteLogger) EVT_CLUSTER_SNAPSHOT_STARTED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_STARTED) PageIO.getVersion(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO.getVersion) ReadWriteMetastorage(org.apache.ignite.internal.processors.cache.persistence.metastorage.ReadWriteMetastorage) S(org.apache.ignite.internal.util.typedef.internal.S) METASTORAGE_CACHE_NAME(org.apache.ignite.internal.processors.cache.persistence.metastorage.MetaStorage.METASTORAGE_CACHE_NAME) GridInternal(org.apache.ignite.internal.processors.task.GridInternal) A(org.apache.ignite.internal.util.typedef.internal.A) MarshallerContextImpl.resolveMappingFileStoreWorkDir(org.apache.ignite.internal.MarshallerContextImpl.resolveMappingFileStoreWorkDir) IOException(java.io.IOException) MetricRegistry(org.apache.ignite.internal.processors.metric.MetricRegistry) T2(org.apache.ignite.internal.util.typedef.T2) BinaryType(org.apache.ignite.binary.BinaryType) GridCacheSharedContext(org.apache.ignite.internal.processors.cache.GridCacheSharedContext) StandaloneGridKernalContext(org.apache.ignite.internal.processors.cache.persistence.wal.reader.StandaloneGridKernalContext) BROADCAST(org.apache.ignite.internal.GridClosureCallMode.BROADCAST) CacheConfiguration(org.apache.ignite.configuration.CacheConfiguration) DFLT_BINARY_METADATA_PATH(org.apache.ignite.configuration.DataStorageConfiguration.DFLT_BINARY_METADATA_PATH) GroupPartitionId.getTypeByPartId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId.getTypeByPartId) PageIdUtils.flag(org.apache.ignite.internal.pagemem.PageIdUtils.flag) CacheObjectContext(org.apache.ignite.internal.processors.cache.CacheObjectContext) START_SNAPSHOT(org.apache.ignite.internal.util.distributed.DistributedProcess.DistributedProcessType.START_SNAPSHOT) IgniteInternalFuture(org.apache.ignite.internal.IgniteInternalFuture) DiscoveryCustomEvent(org.apache.ignite.internal.events.DiscoveryCustomEvent) PageIdUtils.pageId(org.apache.ignite.internal.pagemem.PageIdUtils.pageId) PageIdUtils.toDetailString(org.apache.ignite.internal.pagemem.PageIdUtils.toDetailString) PageStore(org.apache.ignite.internal.pagemem.store.PageStore) IgniteFeatures.nodeSupports(org.apache.ignite.internal.IgniteFeatures.nodeSupports) BiFunction(java.util.function.BiFunction) SYSTEM_POOL(org.apache.ignite.internal.managers.communication.GridIoPolicy.SYSTEM_POOL) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) SimpleFileVisitor(java.nio.file.SimpleFileVisitor) Collection(java.util.Collection) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) MarshallerContextImpl.mappingFileStoreWorkDir(org.apache.ignite.internal.MarshallerContextImpl.mappingFileStoreWorkDir) UUID(java.util.UUID) Collectors(java.util.stream.Collectors) Objects(java.util.Objects) Nullable(org.jetbrains.annotations.Nullable) FastCrc(org.apache.ignite.internal.processors.cache.persistence.wal.crc.FastCrc) InitMessage(org.apache.ignite.internal.util.distributed.InitMessage) FilePageStoreManager.cacheDirectories(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.cacheDirectories) CU(org.apache.ignite.internal.util.typedef.internal.CU) Queue(java.util.Queue) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) MarshallerUtils(org.apache.ignite.marshaller.MarshallerUtils) DataPagePayload(org.apache.ignite.internal.processors.cache.persistence.tree.io.DataPagePayload) SnapshotViewWalker(org.apache.ignite.internal.managers.systemview.walker.SnapshotViewWalker) IgniteFeatures(org.apache.ignite.internal.IgniteFeatures) Function(java.util.function.Function) ConcurrentMap(java.util.concurrent.ConcurrentMap) HashSet(java.util.HashSet) SnapshotView(org.apache.ignite.spi.systemview.view.SnapshotView) GridUnsafe.bufferAddress(org.apache.ignite.internal.util.GridUnsafe.bufferAddress) DFLT_MARSHALLER_PATH(org.apache.ignite.configuration.DataStorageConfiguration.DFLT_MARSHALLER_PATH) LinkedList(java.util.LinkedList) NoSuchElementException(java.util.NoSuchElementException) ExecutorService(java.util.concurrent.ExecutorService) TC_SUBGRID(org.apache.ignite.internal.processors.task.GridTaskThreadContextKey.TC_SUBGRID) GridMessageListener(org.apache.ignite.internal.managers.communication.GridMessageListener) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) FileInputStream(java.io.FileInputStream) BasicFileAttributes(java.nio.file.attribute.BasicFileAttributes) ConcurrentLinkedDeque(java.util.concurrent.ConcurrentLinkedDeque) GridCloseableIterator(org.apache.ignite.internal.util.lang.GridCloseableIterator) Consumer(java.util.function.Consumer) PartitionsExchangeAware(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.PartitionsExchangeAware) DiscoveryDataClusterState(org.apache.ignite.internal.processors.cluster.DiscoveryDataClusterState) DataPageIO(org.apache.ignite.internal.processors.cache.persistence.tree.io.DataPageIO) GridPlainRunnable(org.apache.ignite.internal.util.lang.GridPlainRunnable) BitSet(java.util.BitSet) FileChannel(java.nio.channels.FileChannel) IgniteSnapshot(org.apache.ignite.IgniteSnapshot) TransmissionMeta(org.apache.ignite.internal.managers.communication.TransmissionMeta) GridClosureException(org.apache.ignite.internal.util.lang.GridClosureException) Arrays(java.util.Arrays) CacheType(org.apache.ignite.internal.processors.cache.CacheType) GridFutureAdapter(org.apache.ignite.internal.util.future.GridFutureAdapter) EVT_NODE_LEFT(org.apache.ignite.events.EventType.EVT_NODE_LEFT) MAX_PARTITION_ID(org.apache.ignite.internal.pagemem.PageIdAllocator.MAX_PARTITION_ID) BooleanSupplier(java.util.function.BooleanSupplier) DirectoryStream(java.nio.file.DirectoryStream) GridCloseableIteratorAdapter(org.apache.ignite.internal.util.GridCloseableIteratorAdapter) MarshallerContextImpl.saveMappings(org.apache.ignite.internal.MarshallerContextImpl.saveMappings) ComputeTask(org.apache.ignite.compute.ComputeTask) T_DATA(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO.T_DATA) DataRow(org.apache.ignite.internal.processors.cache.tree.DataRow) PERSISTENCE_CACHE_SNAPSHOT(org.apache.ignite.internal.IgniteFeatures.PERSISTENCE_CACHE_SNAPSHOT) RandomAccessFileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.RandomAccessFileIOFactory) EnumMap(java.util.EnumMap) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) Set(java.util.Set) IgniteInstanceResource(org.apache.ignite.resources.IgniteInstanceResource) GridBusyLock(org.apache.ignite.internal.util.GridBusyLock) TransmissionCancelledException(org.apache.ignite.internal.managers.communication.TransmissionCancelledException) CacheDataRowAdapter(org.apache.ignite.internal.processors.cache.persistence.CacheDataRowAdapter) PageIO.getType(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO.getType) INDEX_PARTITION(org.apache.ignite.internal.pagemem.PageIdAllocator.INDEX_PARTITION) IgniteConfiguration(org.apache.ignite.configuration.IgniteConfiguration) PageIdUtils.pageIndex(org.apache.ignite.internal.pagemem.PageIdUtils.pageIndex) GridCompoundFuture(org.apache.ignite.internal.util.future.GridCompoundFuture) IgniteUtils.isLocalNodeCoordinator(org.apache.ignite.internal.util.IgniteUtils.isLocalNodeCoordinator) CacheObjectBinaryProcessorImpl.resolveBinaryWorkDir(org.apache.ignite.internal.processors.cache.binary.CacheObjectBinaryProcessorImpl.resolveBinaryWorkDir) BufferedOutputStream(java.io.BufferedOutputStream) ArrayList(java.util.ArrayList) GridKernalContext(org.apache.ignite.internal.GridKernalContext) READ(java.nio.file.StandardOpenOption.READ) ClusterNode(org.apache.ignite.cluster.ClusterNode) DB_DEFAULT_FOLDER(org.apache.ignite.internal.processors.cache.persistence.filename.PdsFolderResolver.DB_DEFAULT_FOLDER) GridDhtPartitionsExchangeFuture(org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture) BiConsumer(java.util.function.BiConsumer) IgniteInterruptedException(org.apache.ignite.IgniteInterruptedException) Files(java.nio.file.Files) Executor(java.util.concurrent.Executor) TC_SKIP_AUTH(org.apache.ignite.internal.processors.task.GridTaskThreadContextKey.TC_SKIP_AUTH) FileOutputStream(java.io.FileOutputStream) Marshaller(org.apache.ignite.marshaller.Marshaller) File(java.io.File) GridTopic(org.apache.ignite.internal.GridTopic) Paths(java.nio.file.Paths) IgniteFinishedFutureImpl(org.apache.ignite.internal.util.future.IgniteFinishedFutureImpl) SNAPSHOT_SYS_VIEW(org.apache.ignite.spi.systemview.view.SnapshotView.SNAPSHOT_SYS_VIEW) ArrayDeque(java.util.ArrayDeque) IgniteUuid(org.apache.ignite.lang.IgniteUuid) FLAG_DATA(org.apache.ignite.internal.pagemem.PageIdAllocator.FLAG_DATA) IgniteEx(org.apache.ignite.internal.IgniteEx) IgniteChangeGlobalStateSupport(org.apache.ignite.internal.processors.cluster.IgniteChangeGlobalStateSupport) ByteBuffer(java.nio.ByteBuffer) IgniteFutureCancelledCheckedException(org.apache.ignite.internal.IgniteFutureCancelledCheckedException) SNAPSHOT_SYS_VIEW_DESC(org.apache.ignite.spi.systemview.view.SnapshotView.SNAPSHOT_SYS_VIEW_DESC) FilePageStore(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStore) IgniteFuture(org.apache.ignite.lang.IgniteFuture) PART_FILE_TEMPLATE(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.PART_FILE_TEMPLATE) FailureType(org.apache.ignite.failure.FailureType) IgniteClientDisconnectedCheckedException(org.apache.ignite.internal.IgniteClientDisconnectedCheckedException) Predicate(java.util.function.Predicate) IgniteException(org.apache.ignite.IgniteException) FilePageStoreManager(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager) GridCacheSharedManagerAdapter(org.apache.ignite.internal.processors.cache.GridCacheSharedManagerAdapter) List(java.util.List) EVT_NODE_FAILED(org.apache.ignite.events.EventType.EVT_NODE_FAILED) DiscoveryEventListener(org.apache.ignite.internal.managers.eventstorage.DiscoveryEventListener) IdleVerifyResultV2(org.apache.ignite.internal.processors.cache.verify.IdleVerifyResultV2) FilePageStoreManager.getPartitionFileName(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFileName) NodeStoppingException(org.apache.ignite.internal.NodeStoppingException) DiscoveryEvent(org.apache.ignite.events.DiscoveryEvent) PdsFolderSettings(org.apache.ignite.internal.processors.cache.persistence.filename.PdsFolderSettings) HashMap(java.util.HashMap) GridIoManager(org.apache.ignite.internal.managers.communication.GridIoManager) Deque(java.util.Deque) EVT_CLUSTER_SNAPSHOT_FAILED(org.apache.ignite.events.EventType.EVT_CLUSTER_SNAPSHOT_FAILED) IgniteCallable(org.apache.ignite.lang.IgniteCallable) RejectedExecutionException(java.util.concurrent.RejectedExecutionException) FailureContext(org.apache.ignite.failure.FailureContext) FileIOFactory(org.apache.ignite.internal.processors.cache.persistence.file.FileIOFactory) BALANCE(org.apache.ignite.internal.GridClosureCallMode.BALANCE) PageIO(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO) IgniteThrowableFunction(org.apache.ignite.internal.util.lang.IgniteThrowableFunction) DistributedMetaStorageImpl(org.apache.ignite.internal.processors.metastorage.persistence.DistributedMetaStorageImpl) OutputStream(java.io.OutputStream) DistributedProcess(org.apache.ignite.internal.util.distributed.DistributedProcess) F(org.apache.ignite.internal.util.typedef.F) PageIO.getPageIO(org.apache.ignite.internal.processors.cache.persistence.tree.io.PageIO.getPageIO) AffinityTopologyVersion(org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion) ClusterTopologyCheckedException(org.apache.ignite.internal.cluster.ClusterTopologyCheckedException) TransmissionPolicy(org.apache.ignite.internal.managers.communication.TransmissionPolicy) ADMIN_SNAPSHOT(org.apache.ignite.plugin.security.SecurityPermission.ADMIN_SNAPSHOT) INDEX_FILE_NAME(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.INDEX_FILE_NAME) Collections(java.util.Collections) InputStream(java.io.InputStream) HashSet(java.util.HashSet) BitSet(java.util.BitSet) Set(java.util.Set) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) HashMap(java.util.HashMap) BufferedOutputStream(java.io.BufferedOutputStream) FileOutputStream(java.io.FileOutputStream) OutputStream(java.io.OutputStream) ArrayList(java.util.ArrayList) PageIdUtils.toDetailString(org.apache.ignite.internal.pagemem.PageIdUtils.toDetailString) GridFinishedFuture(org.apache.ignite.internal.util.future.GridFinishedFuture) IgniteCheckedException(org.apache.ignite.IgniteCheckedException) IgniteException(org.apache.ignite.IgniteException) DistributedMetaStorageImpl(org.apache.ignite.internal.processors.metastorage.persistence.DistributedMetaStorageImpl) UUID(java.util.UUID) BufferedOutputStream(java.io.BufferedOutputStream) GroupPartitionId(org.apache.ignite.internal.processors.cache.persistence.partstate.GroupPartitionId) HashSet(java.util.HashSet) GridClosureException(org.apache.ignite.internal.util.lang.GridClosureException) IOException(java.io.IOException) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) FileOutputStream(java.io.FileOutputStream) FilePageStoreManager.getPartitionFile(org.apache.ignite.internal.processors.cache.persistence.file.FilePageStoreManager.getPartitionFile) File(java.io.File)

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