Search in sources :

Example 16 with CancelException

use of org.apache.geode.CancelException in project geode by apache.

the class PrepareNewPersistentMemberMessage method process.

@Override
protected void process(DistributionManager dm) {
    // Set thread local flag to allow entrance through initialization Latch
    int oldLevel = LocalRegion.setThreadInitLevelRequirement(LocalRegion.ANY_INIT);
    PersistentMemberState state = null;
    PersistentMemberID myId = null;
    ReplyException exception = null;
    try {
        // get the region from the path, but do NOT wait on initialization,
        // otherwise we could have a distributed deadlock
        Cache cache = CacheFactory.getInstance(dm.getSystem());
        Region region = cache.getRegion(this.regionPath);
        PersistenceAdvisor persistenceAdvisor = null;
        if (region instanceof DistributedRegion) {
            persistenceAdvisor = ((DistributedRegion) region).getPersistenceAdvisor();
        } else if (region == null) {
            Bucket proxy = PartitionedRegionHelper.getProxyBucketRegion(GemFireCacheImpl.getInstance(), this.regionPath, false);
            if (proxy != null) {
                persistenceAdvisor = proxy.getPersistenceAdvisor();
            }
        }
        if (persistenceAdvisor != null) {
            persistenceAdvisor.prepareNewMember(getSender(), oldId, newId);
        }
    } catch (RegionDestroyedException e) {
        logger.debug("<RegionDestroyed> {}", this);
    } catch (CancelException e) {
        logger.debug("<CancelException> {}", this);
    } catch (VirtualMachineError e) {
        SystemFailure.initiateFailure(e);
        throw e;
    } catch (Throwable t) {
        SystemFailure.checkFailure();
        exception = new ReplyException(t);
    } finally {
        LocalRegion.setThreadInitLevelRequirement(oldLevel);
        ReplyMessage replyMsg = new ReplyMessage();
        replyMsg.setRecipient(getSender());
        replyMsg.setProcessorId(processorId);
        if (exception != null) {
            replyMsg.setException(exception);
        }
        dm.putOutgoing(replyMsg);
    }
}
Also used : RegionDestroyedException(org.apache.geode.cache.RegionDestroyedException) ReplyException(org.apache.geode.distributed.internal.ReplyException) ReplyMessage(org.apache.geode.distributed.internal.ReplyMessage) Bucket(org.apache.geode.internal.cache.partitioned.Bucket) LocalRegion(org.apache.geode.internal.cache.LocalRegion) DistributedRegion(org.apache.geode.internal.cache.DistributedRegion) Region(org.apache.geode.cache.Region) CancelException(org.apache.geode.CancelException) DistributedRegion(org.apache.geode.internal.cache.DistributedRegion) Cache(org.apache.geode.cache.Cache)

Example 17 with CancelException

use of org.apache.geode.CancelException in project geode by apache.

the class RemovePersistentMemberMessage method process.

@Override
protected void process(DistributionManager dm) {
    // Set thread local flag to allow entrance through initialization Latch
    int oldLevel = LocalRegion.setThreadInitLevelRequirement(LocalRegion.ANY_INIT);
    PersistentMemberState state = null;
    PersistentMemberID myId = null;
    ReplyException exception = null;
    try {
        // get the region from the path, but do NOT wait on initialization,
        // otherwise we could have a distributed deadlock
        Cache cache = CacheFactory.getInstance(dm.getSystem());
        Region region = cache.getRegion(this.regionPath);
        PersistenceAdvisor persistenceAdvisor = null;
        if (region instanceof DistributedRegion) {
            persistenceAdvisor = ((DistributedRegion) region).getPersistenceAdvisor();
        } else if (region == null) {
            Bucket proxy = PartitionedRegionHelper.getProxyBucketRegion(GemFireCacheImpl.getInstance(), this.regionPath, false);
            if (proxy != null) {
                persistenceAdvisor = proxy.getPersistenceAdvisor();
            }
        }
        if (persistenceAdvisor != null) {
            if (id != null) {
                persistenceAdvisor.removeMember(id);
            }
            if (initializingId != null) {
                persistenceAdvisor.removeMember(initializingId);
            }
        }
    } catch (RegionDestroyedException e) {
        logger.debug("<RegionDestroyed> {}", this);
    } catch (CancelException e) {
        logger.debug("<CancelException> {}", this);
    } catch (VirtualMachineError e) {
        SystemFailure.initiateFailure(e);
        throw e;
    } catch (Throwable t) {
        SystemFailure.checkFailure();
        exception = new ReplyException(t);
    } finally {
        LocalRegion.setThreadInitLevelRequirement(oldLevel);
        ReplyMessage replyMsg = new ReplyMessage();
        replyMsg.setRecipient(getSender());
        replyMsg.setProcessorId(processorId);
        if (exception != null) {
            replyMsg.setException(exception);
        }
        dm.putOutgoing(replyMsg);
    }
}
Also used : RegionDestroyedException(org.apache.geode.cache.RegionDestroyedException) ReplyException(org.apache.geode.distributed.internal.ReplyException) ReplyMessage(org.apache.geode.distributed.internal.ReplyMessage) Bucket(org.apache.geode.internal.cache.partitioned.Bucket) LocalRegion(org.apache.geode.internal.cache.LocalRegion) DistributedRegion(org.apache.geode.internal.cache.DistributedRegion) Region(org.apache.geode.cache.Region) CancelException(org.apache.geode.CancelException) DistributedRegion(org.apache.geode.internal.cache.DistributedRegion) Cache(org.apache.geode.cache.Cache)

Example 18 with CancelException

use of org.apache.geode.CancelException in project geode by apache.

the class GatewayReceiverCommand method cmdExecute.

@Override
public void cmdExecute(Message clientMessage, ServerConnection serverConnection, long start) throws IOException, InterruptedException {
    Part regionNamePart = null, keyPart = null, valuePart = null, callbackArgPart = null;
    String regionName = null;
    Object callbackArg = null, key = null;
    int partNumber = 0;
    CachedRegionHelper crHelper = serverConnection.getCachedRegionHelper();
    GatewayReceiverStats stats = (GatewayReceiverStats) serverConnection.getCacheServerStats();
    EventID eventId = null;
    LocalRegion region = null;
    List<BatchException70> exceptions = new ArrayList<BatchException70>();
    Throwable fatalException = null;
    // requiresResponse = true;// let PROCESS_BATCH deal with this itself
    {
        long oldStart = start;
        start = DistributionStats.getStatTime();
        stats.incReadProcessBatchRequestTime(start - oldStart);
    }
    Part callbackArgExistsPart;
    // Get early ack flag. This test should eventually be moved up above this switch
    // statement so that all messages can take advantage of it.
    // msg.getEarlyAck();
    boolean earlyAck = false;
    stats.incBatchSize(clientMessage.getPayloadLength());
    // Retrieve the number of events
    Part numberOfEventsPart = clientMessage.getPart(0);
    int numberOfEvents = numberOfEventsPart.getInt();
    stats.incEventsReceived(numberOfEvents);
    // Retrieve the batch id
    Part batchIdPart = clientMessage.getPart(1);
    int batchId = batchIdPart.getInt();
    // Instead, drop the batch and continue.
    if (batchId <= serverConnection.getLatestBatchIdReplied()) {
        if (GatewayReceiver.APPLY_RETRIES) {
            // Do nothing!!!
            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_RECEIVED_PROCESS_BATCH_REQUEST_0_THAT_HAS_ALREADY_BEEN_OR_IS_BEING_PROCESSED_GEMFIRE_GATEWAY_APPLYRETRIES_IS_SET_SO_THIS_BATCH_WILL_BE_PROCESSED_ANYWAY, batchId));
        } else {
            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_RECEIVED_PROCESS_BATCH_REQUEST_0_THAT_HAS_ALREADY_BEEN_OR_IS_BEING_PROCESSED__THIS_PROCESS_BATCH_REQUEST_IS_BEING_IGNORED, batchId));
            writeReply(clientMessage, serverConnection, batchId, numberOfEvents);
            return;
        }
        stats.incDuplicateBatchesReceived();
    }
    // Verify the batches arrive in order
    if (batchId != serverConnection.getLatestBatchIdReplied() + 1) {
        logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_RECEIVED_PROCESS_BATCH_REQUEST_0_OUT_OF_ORDER_THE_ID_OF_THE_LAST_BATCH_PROCESSED_WAS_1_THIS_BATCH_REQUEST_WILL_BE_PROCESSED_BUT_SOME_MESSAGES_MAY_HAVE_BEEN_LOST, new Object[] { batchId, serverConnection.getLatestBatchIdReplied() }));
        stats.incOutoforderBatchesReceived();
    }
    if (logger.isDebugEnabled()) {
        logger.debug("Received process batch request {} that will be processed.", batchId);
    }
    // Not sure if earlyAck makes sense with sliding window
    if (earlyAck) {
        serverConnection.incrementLatestBatchIdReplied(batchId);
        // writeReply(msg, servConn);
        // servConn.setAsTrue(RESPONDED);
        {
            long oldStart = start;
            start = DistributionStats.getStatTime();
            stats.incWriteProcessBatchResponseTime(start - oldStart);
        }
        stats.incEarlyAcks();
    }
    if (logger.isDebugEnabled()) {
        logger.debug("{}: Received process batch request {} containing {} events ({} bytes) with {} acknowledgement on {}", serverConnection.getName(), batchId, numberOfEvents, clientMessage.getPayloadLength(), (earlyAck ? "early" : "normal"), serverConnection.getSocketString());
        if (earlyAck) {
            logger.debug("{}: Sent process batch early response for batch {} containing {} events ({} bytes) with {} acknowledgement on {}", serverConnection.getName(), batchId, numberOfEvents, clientMessage.getPayloadLength(), (earlyAck ? "early" : "normal"), serverConnection.getSocketString());
        }
    }
    // logger.warn("Received process batch request " + batchId + " containing
    // " + numberOfEvents + " events (" + msg.getPayloadLength() + " bytes) with
    // " + (earlyAck ? "early" : "normal") + " acknowledgement on " +
    // getSocketString());
    // if (earlyAck) {
    // logger.warn("Sent process batch early response for batch " + batchId +
    // " containing " + numberOfEvents + " events (" + msg.getPayloadLength() +
    // " bytes) with " + (earlyAck ? "early" : "normal") + " acknowledgement on
    // " + getSocketString());
    // }
    // Retrieve the events from the message parts. The '2' below
    // represents the number of events (part0) and the batchId (part1)
    partNumber = 2;
    int dsid = clientMessage.getPart(partNumber++).getInt();
    boolean removeOnException = clientMessage.getPart(partNumber++).getSerializedForm()[0] == 1 ? true : false;
    // Keep track of whether a response has been written for
    // exceptions
    boolean wroteResponse = earlyAck;
    // event received in batch also have PDX events at the start of the batch,to
    // represent correct index on which the exception occurred, number of PDX
    // events need to be subtratced.
    //
    int indexWithoutPDXEvent = -1;
    for (int i = 0; i < numberOfEvents; i++) {
        boolean isPdxEvent = false;
        indexWithoutPDXEvent++;
        // System.out.println("Processing event " + i + " in batch " + batchId + "
        // starting with part number " + partNumber);
        Part actionTypePart = clientMessage.getPart(partNumber);
        int actionType = actionTypePart.getInt();
        long versionTimeStamp = VersionTag.ILLEGAL_VERSION_TIMESTAMP;
        EventIDHolder clientEvent = null;
        boolean callbackArgExists = false;
        try {
            Part possibleDuplicatePart = clientMessage.getPart(partNumber + 1);
            byte[] possibleDuplicatePartBytes;
            try {
                possibleDuplicatePartBytes = (byte[]) possibleDuplicatePart.getObject();
            } catch (Exception e) {
                logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                throw e;
            }
            boolean possibleDuplicate = possibleDuplicatePartBytes[0] == 0x01;
            // Make sure instance variables are null before each iteration
            regionName = null;
            key = null;
            callbackArg = null;
            // Retrieve the region name from the message parts
            regionNamePart = clientMessage.getPart(partNumber + 2);
            regionName = regionNamePart.getString();
            if (regionName.equals(PeerTypeRegistration.REGION_FULL_PATH)) {
                indexWithoutPDXEvent--;
                isPdxEvent = true;
            }
            // Retrieve the event id from the message parts
            // This was going to be used to determine possible
            // duplication of events, but it is unused now. In
            // fact the event id is overridden by the FROM_GATEWAY
            // token.
            Part eventIdPart = clientMessage.getPart(partNumber + 3);
            eventIdPart.setVersion(serverConnection.getClientVersion());
            // String eventId = eventIdPart.getString();
            try {
                eventId = (EventID) eventIdPart.getObject();
            } catch (Exception e) {
                logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                throw e;
            }
            // Retrieve the key from the message parts
            keyPart = clientMessage.getPart(partNumber + 4);
            try {
                key = keyPart.getStringOrObject();
            } catch (Exception e) {
                logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                throw e;
            }
            switch(actionType) {
                case // Create
                0:
                    /*
             * CLIENT EXCEPTION HANDLING TESTING CODE String keySt = (String) key;
             * System.out.println("Processing new key: " + key); if (keySt.startsWith("failure")) {
             * throw new Exception(LocalizedStrings
             * .ProcessBatch_THIS_EXCEPTION_REPRESENTS_A_FAILURE_ON_THE_SERVER
             * .toLocalizedString()); }
             */
                    // Retrieve the value from the message parts (do not deserialize it)
                    valuePart = clientMessage.getPart(partNumber + 5);
                    // try {
                    // logger.warn(getName() + ": Creating key " + key + " value " +
                    // valuePart.getObject());
                    // } catch (Exception e) {}
                    // Retrieve the callbackArg from the message parts if necessary
                    int index = partNumber + 6;
                    callbackArgExistsPart = clientMessage.getPart(index++);
                    {
                        byte[] partBytes = (byte[]) callbackArgExistsPart.getObject();
                        callbackArgExists = partBytes[0] == 0x01;
                    }
                    if (callbackArgExists) {
                        callbackArgPart = clientMessage.getPart(index++);
                        try {
                            callbackArg = callbackArgPart.getObject();
                        } catch (Exception e) {
                            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_CREATE_REQUEST_1_FOR_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                            throw e;
                        }
                    }
                    if (logger.isDebugEnabled()) {
                        logger.debug("{}: Processing batch create request {} on {} for region {} key {} value {} callbackArg {}, eventId={}", serverConnection.getName(), batchId, serverConnection.getSocketString(), regionName, key, valuePart, callbackArg, eventId);
                    }
                    versionTimeStamp = clientMessage.getPart(index++).getLong();
                    // Process the create request
                    if (key == null || regionName == null) {
                        StringId message = null;
                        Object[] messageArgs = new Object[] { serverConnection.getName(), Integer.valueOf(batchId) };
                        if (key == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_REGION_NAME_FOR_THE_BATCH_CREATE_REQUEST_1_IS_NULL;
                        }
                        if (regionName == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_REGION_NAME_FOR_THE_BATCH_CREATE_REQUEST_1_IS_NULL;
                        }
                        String s = message.toLocalizedString(messageArgs);
                        logger.warn(s);
                        throw new Exception(s);
                    }
                    region = (LocalRegion) crHelper.getRegion(regionName);
                    if (region == null) {
                        handleRegionNull(serverConnection, regionName, batchId);
                    } else {
                        clientEvent = new EventIDHolder(eventId);
                        if (versionTimeStamp > 0) {
                            VersionTag tag = VersionTag.create(region.getVersionMember());
                            tag.setIsGatewayTag(true);
                            tag.setVersionTimeStamp(versionTimeStamp);
                            tag.setDistributedSystemId(dsid);
                            clientEvent.setVersionTag(tag);
                        }
                        clientEvent.setPossibleDuplicate(possibleDuplicate);
                        handleMessageRetry(region, clientEvent);
                        try {
                            byte[] value = valuePart.getSerializedForm();
                            boolean isObject = valuePart.isObject();
                            // [sumedh] This should be done on client while sending
                            // since that is the WAN gateway
                            AuthorizeRequest authzRequest = serverConnection.getAuthzRequest();
                            if (authzRequest != null) {
                                PutOperationContext putContext = authzRequest.putAuthorize(regionName, key, value, isObject, callbackArg);
                                value = putContext.getSerializedValue();
                                isObject = putContext.isObject();
                            }
                            // Attempt to create the entry
                            boolean result = false;
                            if (isPdxEvent) {
                                result = addPdxType(crHelper, key, value);
                            } else {
                                result = region.basicBridgeCreate(key, value, isObject, callbackArg, serverConnection.getProxyID(), false, clientEvent, false);
                                // attempt to update the entry
                                if (!result) {
                                    result = region.basicBridgePut(key, value, null, isObject, callbackArg, serverConnection.getProxyID(), false, clientEvent);
                                }
                            }
                            if (result || clientEvent.isConcurrencyConflict()) {
                                serverConnection.setModificationInfo(true, regionName, key);
                                stats.incCreateRequest();
                            } else {
                                // This exception will be logged in the catch block below
                                throw new Exception(LocalizedStrings.ProcessBatch_0_FAILED_TO_CREATE_OR_UPDATE_ENTRY_FOR_REGION_1_KEY_2_VALUE_3_CALLBACKARG_4.toLocalizedString(new Object[] { serverConnection.getName(), regionName, key, valuePart, callbackArg }));
                            }
                        } catch (Exception e) {
                            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_CREATE_REQUEST_1_FOR_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                            throw e;
                        }
                    }
                    break;
                case // Update
                1:
                    /*
             * CLIENT EXCEPTION HANDLING TESTING CODE keySt = (String) key;
             * System.out.println("Processing updated key: " + key); if
             * (keySt.startsWith("failure")) { throw new Exception(LocalizedStrings
             * .ProcessBatch_THIS_EXCEPTION_REPRESENTS_A_FAILURE_ON_THE_SERVER
             * .toLocalizedString()); }
             */
                    // Retrieve the value from the message parts (do not deserialize it)
                    valuePart = clientMessage.getPart(partNumber + 5);
                    // try {
                    // logger.warn(getName() + ": Updating key " + key + " value " +
                    // valuePart.getObject());
                    // } catch (Exception e) {}
                    // Retrieve the callbackArg from the message parts if necessary
                    index = partNumber + 6;
                    callbackArgExistsPart = clientMessage.getPart(index++);
                    {
                        byte[] partBytes = (byte[]) callbackArgExistsPart.getObject();
                        callbackArgExists = partBytes[0] == 0x01;
                    }
                    if (callbackArgExists) {
                        callbackArgPart = clientMessage.getPart(index++);
                        try {
                            callbackArg = callbackArgPart.getObject();
                        } catch (Exception e) {
                            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_UPDATE_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                            throw e;
                        }
                    }
                    versionTimeStamp = clientMessage.getPart(index++).getLong();
                    if (logger.isDebugEnabled()) {
                        logger.debug("{}: Processing batch update request {} on {} for region {} key {} value {} callbackArg {}", serverConnection.getName(), batchId, serverConnection.getSocketString(), regionName, key, valuePart, callbackArg);
                    }
                    // Process the update request
                    if (key == null || regionName == null) {
                        StringId message = null;
                        Object[] messageArgs = new Object[] { serverConnection.getName(), Integer.valueOf(batchId) };
                        if (key == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_KEY_FOR_THE_BATCH_UPDATE_REQUEST_1_IS_NULL;
                        }
                        if (regionName == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_REGION_NAME_FOR_THE_BATCH_UPDATE_REQUEST_1_IS_NULL;
                        }
                        String s = message.toLocalizedString(messageArgs);
                        logger.warn(s);
                        throw new Exception(s);
                    }
                    region = (LocalRegion) crHelper.getRegion(regionName);
                    if (region == null) {
                        handleRegionNull(serverConnection, regionName, batchId);
                    } else {
                        clientEvent = new EventIDHolder(eventId);
                        if (versionTimeStamp > 0) {
                            VersionTag tag = VersionTag.create(region.getVersionMember());
                            tag.setIsGatewayTag(true);
                            tag.setVersionTimeStamp(versionTimeStamp);
                            tag.setDistributedSystemId(dsid);
                            clientEvent.setVersionTag(tag);
                        }
                        clientEvent.setPossibleDuplicate(possibleDuplicate);
                        handleMessageRetry(region, clientEvent);
                        try {
                            byte[] value = valuePart.getSerializedForm();
                            boolean isObject = valuePart.isObject();
                            AuthorizeRequest authzRequest = serverConnection.getAuthzRequest();
                            if (authzRequest != null) {
                                PutOperationContext putContext = authzRequest.putAuthorize(regionName, key, value, isObject, callbackArg, PutOperationContext.UPDATE);
                                value = putContext.getSerializedValue();
                                isObject = putContext.isObject();
                            }
                            boolean result = false;
                            if (isPdxEvent) {
                                result = addPdxType(crHelper, key, value);
                            } else {
                                result = region.basicBridgePut(key, value, null, isObject, callbackArg, serverConnection.getProxyID(), false, clientEvent);
                            }
                            if (result || clientEvent.isConcurrencyConflict()) {
                                serverConnection.setModificationInfo(true, regionName, key);
                                stats.incUpdateRequest();
                            } else {
                                final Object[] msgArgs = new Object[] { serverConnection.getName(), regionName, key, valuePart, callbackArg };
                                final StringId message = LocalizedStrings.ProcessBatch_0_FAILED_TO_UPDATE_ENTRY_FOR_REGION_1_KEY_2_VALUE_3_AND_CALLBACKARG_4;
                                String s = message.toLocalizedString(msgArgs);
                                logger.info(s);
                                throw new Exception(s);
                            }
                        } catch (CancelException e) {
                            // FIXME better exception hierarchy would avoid this check
                            if (serverConnection.getCachedRegionHelper().getCache().getCancelCriterion().isCancelInProgress()) {
                                if (logger.isDebugEnabled()) {
                                    logger.debug("{} ignoring message of type {} from client {} because shutdown occurred during message processing.", serverConnection.getName(), MessageType.getString(clientMessage.getMessageType()), serverConnection.getProxyID());
                                }
                                serverConnection.setFlagProcessMessagesAsFalse();
                                serverConnection.setClientDisconnectedException(e);
                            } else {
                                throw e;
                            }
                            return;
                        } catch (Exception e) {
                            // Preserve the connection under all circumstances
                            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_UPDATE_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                            throw e;
                        }
                    }
                    break;
                case // Destroy
                2:
                    // Retrieve the callbackArg from the message parts if necessary
                    index = partNumber + 5;
                    callbackArgExistsPart = clientMessage.getPart(index++);
                    {
                        byte[] partBytes = (byte[]) callbackArgExistsPart.getObject();
                        callbackArgExists = partBytes[0] == 0x01;
                    }
                    if (callbackArgExists) {
                        callbackArgPart = clientMessage.getPart(index++);
                        try {
                            callbackArg = callbackArgPart.getObject();
                        } catch (Exception e) {
                            logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_DESTROY_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                            throw e;
                        }
                    }
                    versionTimeStamp = clientMessage.getPart(index++).getLong();
                    if (logger.isDebugEnabled()) {
                        logger.debug("{}: Processing batch destroy request {} on {} for region {} key {}", serverConnection.getName(), batchId, serverConnection.getSocketString(), regionName, key);
                    }
                    // Process the destroy request
                    if (key == null || regionName == null) {
                        StringId message = null;
                        if (key == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_KEY_FOR_THE_BATCH_DESTROY_REQUEST_1_IS_NULL;
                        }
                        if (regionName == null) {
                            message = LocalizedStrings.ProcessBatch_0_THE_INPUT_REGION_NAME_FOR_THE_BATCH_DESTROY_REQUEST_1_IS_NULL;
                        }
                        Object[] messageArgs = new Object[] { serverConnection.getName(), Integer.valueOf(batchId) };
                        String s = message.toLocalizedString(messageArgs);
                        logger.warn(s);
                        throw new Exception(s);
                    }
                    region = (LocalRegion) crHelper.getRegion(regionName);
                    if (region == null) {
                        handleRegionNull(serverConnection, regionName, batchId);
                    } else {
                        clientEvent = new EventIDHolder(eventId);
                        if (versionTimeStamp > 0) {
                            VersionTag tag = VersionTag.create(region.getVersionMember());
                            tag.setIsGatewayTag(true);
                            tag.setVersionTimeStamp(versionTimeStamp);
                            tag.setDistributedSystemId(dsid);
                            clientEvent.setVersionTag(tag);
                        }
                        handleMessageRetry(region, clientEvent);
                        // Destroy the entry
                        try {
                            AuthorizeRequest authzRequest = serverConnection.getAuthzRequest();
                            if (authzRequest != null) {
                                DestroyOperationContext destroyContext = authzRequest.destroyAuthorize(regionName, key, callbackArg);
                                callbackArg = destroyContext.getCallbackArg();
                            }
                            region.basicBridgeDestroy(key, callbackArg, serverConnection.getProxyID(), false, clientEvent);
                            serverConnection.setModificationInfo(true, regionName, key);
                            stats.incDestroyRequest();
                        } catch (EntryNotFoundException e) {
                            logger.info(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_DURING_BATCH_DESTROY_NO_ENTRY_WAS_FOUND_FOR_KEY_1, new Object[] { serverConnection.getName(), key }));
                        // throw new Exception(e);
                        }
                    }
                    break;
                case // Update Time-stamp for a RegionEntry
                3:
                    try {
                        // Region name
                        regionNamePart = clientMessage.getPart(partNumber + 2);
                        regionName = regionNamePart.getString();
                        // Retrieve the event id from the message parts
                        eventIdPart = clientMessage.getPart(partNumber + 3);
                        eventId = (EventID) eventIdPart.getObject();
                        // Retrieve the key from the message parts
                        keyPart = clientMessage.getPart(partNumber + 4);
                        key = keyPart.getStringOrObject();
                        // Retrieve the callbackArg from the message parts if necessary
                        index = partNumber + 5;
                        callbackArgExistsPart = clientMessage.getPart(index++);
                        byte[] partBytes = (byte[]) callbackArgExistsPart.getObject();
                        callbackArgExists = partBytes[0] == 0x01;
                        if (callbackArgExists) {
                            callbackArgPart = clientMessage.getPart(index++);
                            callbackArg = callbackArgPart.getObject();
                        }
                    } catch (Exception e) {
                        logger.warn(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_UPDATE_VERSION_REQUEST_1_CONTAINING_2_EVENTS, new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) }), e);
                        throw e;
                    }
                    versionTimeStamp = clientMessage.getPart(index++).getLong();
                    if (logger.isDebugEnabled()) {
                        logger.debug("{}: Processing batch update-version request {} on {} for region {} key {} value {} callbackArg {}", serverConnection.getName(), batchId, serverConnection.getSocketString(), regionName, key, valuePart, callbackArg);
                    }
                    // Process the update time-stamp request
                    if (key == null || regionName == null) {
                        StringId message = LocalizedStrings.ProcessBatch_0_CAUGHT_EXCEPTION_PROCESSING_BATCH_UPDATE_VERSION_REQUEST_1_CONTAINING_2_EVENTS;
                        Object[] messageArgs = new Object[] { serverConnection.getName(), Integer.valueOf(batchId), Integer.valueOf(numberOfEvents) };
                        String s = message.toLocalizedString(messageArgs);
                        logger.warn(s);
                        throw new Exception(s);
                    } else {
                        region = (LocalRegion) crHelper.getRegion(regionName);
                        if (region == null) {
                            handleRegionNull(serverConnection, regionName, batchId);
                        } else {
                            clientEvent = new EventIDHolder(eventId);
                            if (versionTimeStamp > 0) {
                                VersionTag tag = VersionTag.create(region.getVersionMember());
                                tag.setIsGatewayTag(true);
                                tag.setVersionTimeStamp(versionTimeStamp);
                                tag.setDistributedSystemId(dsid);
                                clientEvent.setVersionTag(tag);
                            }
                            // Update the version tag
                            try {
                                region.basicBridgeUpdateVersionStamp(key, callbackArg, serverConnection.getProxyID(), false, clientEvent);
                            } catch (EntryNotFoundException e) {
                                logger.info(LocalizedMessage.create(LocalizedStrings.ProcessBatch_0_DURING_BATCH_UPDATE_VERSION_NO_ENTRY_WAS_FOUND_FOR_KEY_1, new Object[] { serverConnection.getName(), key }));
                            // throw new Exception(e);
                            }
                        }
                    }
                    break;
                default:
                    logger.fatal(LocalizedMessage.create(LocalizedStrings.Processbatch_0_UNKNOWN_ACTION_TYPE_1_FOR_BATCH_FROM_2, new Object[] { serverConnection.getName(), Integer.valueOf(actionType), serverConnection.getSocketString() }));
                    stats.incUnknowsOperationsReceived();
            }
        } catch (CancelException e) {
            if (logger.isDebugEnabled()) {
                logger.debug("{} ignoring message of type {} from client {} because shutdown occurred during message processing.", serverConnection.getName(), MessageType.getString(clientMessage.getMessageType()), serverConnection.getProxyID());
            }
            serverConnection.setFlagProcessMessagesAsFalse();
            serverConnection.setClientDisconnectedException(e);
            return;
        } catch (Exception e) {
            // If an interrupted exception is thrown , rethrow it
            checkForInterrupt(serverConnection, e);
            // If we have an issue with the PDX registry, stop processing more data
            if (e.getCause() instanceof PdxRegistryMismatchException) {
                fatalException = e.getCause();
                logger.fatal(LocalizedMessage.create(LocalizedStrings.GatewayReceiver_PDX_CONFIGURATION, new Object[] { serverConnection.getMembershipID() }), e.getCause());
                break;
            }
            // write the batch exception to the caller and break
            if (!wroteResponse) {
                // Increment the batch id unless the received batch id is -1 (a
                // failover batch)
                DistributedSystem ds = crHelper.getCache().getDistributedSystem();
                String exceptionMessage = LocalizedStrings.GatewayReceiver_EXCEPTION_WHILE_PROCESSING_BATCH.toLocalizedString(new Object[] { ((InternalDistributedSystem) ds).getDistributionManager().getDistributedSystemId(), ds.getDistributedMember() });
                BatchException70 be = new BatchException70(exceptionMessage, e, indexWithoutPDXEvent, batchId);
                exceptions.add(be);
                if (!removeOnException) {
                    break;
                }
            // servConn.setAsTrue(RESPONDED);
            // wroteResponse = true;
            // break;
            } else {
                // occurred.
                return;
            }
        } finally {
            // Increment the partNumber
            if (actionType == 0 || /* create */
            actionType == 1) /* update */
            {
                if (callbackArgExists) {
                    partNumber += 9;
                } else {
                    partNumber += 8;
                }
            } else if (actionType == 2) /* destroy */
            {
                if (callbackArgExists) {
                    partNumber += 8;
                } else {
                    partNumber += 7;
                }
            } else if (actionType == 3) /* update-version */
            {
                if (callbackArgExists) {
                    partNumber += 8;
                } else {
                    partNumber += 7;
                }
            }
        }
    }
    {
        long oldStart = start;
        start = DistributionStats.getStatTime();
        stats.incProcessBatchTime(start - oldStart);
    }
    if (fatalException != null) {
        serverConnection.incrementLatestBatchIdReplied(batchId);
        writeFatalException(clientMessage, fatalException, serverConnection, batchId);
        serverConnection.setAsTrue(RESPONDED);
    } else if (!exceptions.isEmpty()) {
        serverConnection.incrementLatestBatchIdReplied(batchId);
        writeBatchException(clientMessage, exceptions, serverConnection, batchId);
        serverConnection.setAsTrue(RESPONDED);
    } else if (!wroteResponse) {
        // Increment the batch id unless the received batch id is -1 (a failover
        // batch)
        serverConnection.incrementLatestBatchIdReplied(batchId);
        writeReply(clientMessage, serverConnection, batchId, numberOfEvents);
        serverConnection.setAsTrue(RESPONDED);
        stats.incWriteProcessBatchResponseTime(DistributionStats.getStatTime() - start);
        if (logger.isDebugEnabled()) {
            logger.debug("{}: Sent process batch normal response for batch {} containing {} events ({} bytes) with {} acknowledgement on {}", serverConnection.getName(), batchId, numberOfEvents, clientMessage.getPayloadLength(), (earlyAck ? "early" : "normal"), serverConnection.getSocketString());
        }
    // logger.warn("Sent process batch normal response for batch " +
    // batchId + " containing " + numberOfEvents + " events (" +
    // msg.getPayloadLength() + " bytes) with " + (earlyAck ? "early" :
    // "normal") + " acknowledgement on " + getSocketString());
    }
}
Also used : AuthorizeRequest(org.apache.geode.internal.security.AuthorizeRequest) ArrayList(java.util.ArrayList) LocalRegion(org.apache.geode.internal.cache.LocalRegion) DistributedSystem(org.apache.geode.distributed.DistributedSystem) InternalDistributedSystem(org.apache.geode.distributed.internal.InternalDistributedSystem) CachedRegionHelper(org.apache.geode.internal.cache.tier.CachedRegionHelper) PdxRegistryMismatchException(org.apache.geode.pdx.PdxRegistryMismatchException) VersionTag(org.apache.geode.internal.cache.versions.VersionTag) EntryNotFoundException(org.apache.geode.cache.EntryNotFoundException) EventIDHolder(org.apache.geode.internal.cache.EventIDHolder) PdxRegistryMismatchException(org.apache.geode.pdx.PdxRegistryMismatchException) RegionDestroyedException(org.apache.geode.cache.RegionDestroyedException) EntryNotFoundException(org.apache.geode.cache.EntryNotFoundException) CacheClosedException(org.apache.geode.cache.CacheClosedException) PdxConfigurationException(org.apache.geode.pdx.PdxConfigurationException) CancelException(org.apache.geode.CancelException) IOException(java.io.IOException) DestroyOperationContext(org.apache.geode.cache.operations.DestroyOperationContext) StringId(org.apache.geode.i18n.StringId) BatchException70(org.apache.geode.internal.cache.wan.BatchException70) Part(org.apache.geode.internal.cache.tier.sockets.Part) EventID(org.apache.geode.internal.cache.EventID) PutOperationContext(org.apache.geode.cache.operations.PutOperationContext) CancelException(org.apache.geode.CancelException) GatewayReceiverStats(org.apache.geode.internal.cache.wan.GatewayReceiverStats)

Example 19 with CancelException

use of org.apache.geode.CancelException in project geode by apache.

the class ServerInterestRegistrationMessage method process.

@Override
protected void process(DistributionManager dm) {
    // Get the proxy for the proxy id
    try {
        CacheClientNotifier clientNotifier = CacheClientNotifier.getInstance();
        if (clientNotifier != null) {
            CacheClientProxy proxy = clientNotifier.getClientProxy(this.clientId);
            // message on to the proxy for processing
            if (proxy != null) {
                proxy.processInterestMessage(this.clientMessage);
            }
        }
    } finally {
        ReplyMessage reply = new ReplyMessage();
        reply.setProcessorId(this.processorId);
        reply.setRecipient(getSender());
        try {
            dm.putOutgoing(reply);
        } catch (CancelException ignore) {
        // can't send a reply, so ignore the exception
        }
    }
}
Also used : CancelException(org.apache.geode.CancelException) ReplyMessage(org.apache.geode.distributed.internal.ReplyMessage)

Example 20 with CancelException

use of org.apache.geode.CancelException in project geode by apache.

the class CustomEntryConcurrentHashMap method clear.

/**
   * Removes all of the mappings from this map.
   */
@Override
public void clear() {
    ArrayList<HashEntry<?, ?>> entries = null;
    try {
        for (int i = 0; i < this.segments.length; ++i) {
            entries = this.segments[i].clear(entries);
        }
    } finally {
        if (entries != null) {
            final ArrayList<HashEntry<?, ?>> clearedEntries = entries;
            final Runnable runnable = new Runnable() {

                public void run() {
                    for (HashEntry<?, ?> he : clearedEntries) {
                        for (HashEntry<?, ?> p = he; p != null; p = p.getNextEntry()) {
                            synchronized (p) {
                                ((OffHeapRegionEntry) p).release();
                            }
                        }
                    }
                }
            };
            boolean submitted = false;
            InternalDistributedSystem ids = InternalDistributedSystem.getConnectedInstance();
            if (ids != null) {
                try {
                    ids.getDistributionManager().getWaitingThreadPool().execute(runnable);
                    submitted = true;
                } catch (RejectedExecutionException e) {
                // fall through with submitted false
                } catch (CancelException e) {
                // fall through with submitted false
                } catch (NullPointerException e) {
                // fall through with submitted false
                }
            }
            if (!submitted) {
                String name = this.getClass().getSimpleName() + "@" + this.hashCode() + " Clear Thread";
                Thread thread = new Thread(runnable, name);
                thread.setDaemon(true);
                thread.start();
            }
        }
    }
}
Also used : OffHeapRegionEntry(org.apache.geode.internal.cache.OffHeapRegionEntry) RejectedExecutionException(java.util.concurrent.RejectedExecutionException) InternalDistributedSystem(org.apache.geode.distributed.internal.InternalDistributedSystem) CancelException(org.apache.geode.CancelException)

Aggregations

CancelException (org.apache.geode.CancelException)135 RegionDestroyedException (org.apache.geode.cache.RegionDestroyedException)46 IOException (java.io.IOException)40 ReplyException (org.apache.geode.distributed.internal.ReplyException)30 InternalDistributedMember (org.apache.geode.distributed.internal.membership.InternalDistributedMember)25 CacheClosedException (org.apache.geode.cache.CacheClosedException)23 Region (org.apache.geode.cache.Region)22 PartitionedRegion (org.apache.geode.internal.cache.PartitionedRegion)21 LocalRegion (org.apache.geode.internal.cache.LocalRegion)18 Set (java.util.Set)16 Cache (org.apache.geode.cache.Cache)16 CacheException (org.apache.geode.cache.CacheException)16 HashSet (java.util.HashSet)15 Iterator (java.util.Iterator)15 QueryException (org.apache.geode.cache.query.QueryException)15 ArrayList (java.util.ArrayList)13 EntryNotFoundException (org.apache.geode.cache.EntryNotFoundException)13 QueryInvocationTargetException (org.apache.geode.cache.query.QueryInvocationTargetException)13 DistributedSystemDisconnectedException (org.apache.geode.distributed.DistributedSystemDisconnectedException)13 SerializableRunnable (org.apache.geode.test.dunit.SerializableRunnable)13