Search in sources :

Example 6 with StringId

use of org.apache.geode.i18n.StringId in project geode by apache.

the class BasicI18nJUnitTest method getAllStringIds.

/**
   * Get all of the StringId instances via reflection.
   * 
   * @return a set of all StringId declarations within the product
   */
private Set<StringId> getAllStringIds() {
    final Set<StringId> allStringIds = new HashSet<StringId>();
    for (String className : getStringIdDefiningClasses()) {
        try {
            Class<?> c = Class.forName(className);
            Field[] fields = c.getDeclaredFields();
            final String msg = "Found no StringIds in " + className;
            assertTrue(msg, fields.length > 0);
            for (Field f : fields) {
                f.setAccessible(true);
                StringId instance = (StringId) f.get(null);
                allStringIds.add(instance);
            }
        } catch (ClassNotFoundException cnfe) {
            throw new AssertionError(cnfe.toString(), cnfe);
        } catch (Exception e) {
            String exMsg = "Reflection attempt failed while attempting to find all" + " StringId instances. ";
            throw new AssertionError(exMsg + e.toString(), e);
        }
    }
    return allStringIds;
}
Also used : Field(java.lang.reflect.Field) StringId(org.apache.geode.i18n.StringId) HashSet(java.util.HashSet) LinkedHashSet(java.util.LinkedHashSet)

Example 7 with StringId

use of org.apache.geode.i18n.StringId in project geode by apache.

the class LocalizedMessageJUnitTest method testGetThrowable.

@Test
public void testGetThrowable() {
    final Throwable t = new Throwable();
    final StringId stringId = new StringId(100, "This is a message for testGetThrowable");
    final LocalizedMessage message = LocalizedMessage.create(stringId, t);
    assertNotNull(message.getThrowable());
    assertEquals(t, message.getThrowable());
    assertTrue(t == message.getThrowable());
}
Also used : StringId(org.apache.geode.i18n.StringId) UnitTest(org.apache.geode.test.junit.categories.UnitTest) Test(org.junit.Test)

Example 8 with StringId

use of org.apache.geode.i18n.StringId in project geode by apache.

the class ReplyProcessor21 method timeout.

/**
   * process a wait-timeout. Usually suspectThem would be used in the first timeout, followed by a
   * subsequent use of disconnectThem
   * 
   * @param suspectThem whether to ask the membership manager to suspect the unresponsive members
   * @param severeAlert whether to ask the membership manager to disconnect the unresponseive
   *        members
   */
private void timeout(boolean suspectThem, boolean severeAlert) {
    if (!this.processTimeout())
        return;
    Set activeMembers = getDistributionManagerIds();
    // an alert that will show up in the console
    long timeout = getAckWaitThreshold();
    final Object[] msgArgs = new Object[] { Long.valueOf(timeout + (severeAlert ? getSevereAlertThreshold() : 0)), this, getDistributionManager().getId(), activeMembers };
    final StringId msg = LocalizedStrings.ReplyProcessor21_0_SEC_HAVE_ELAPSED_WHILE_WAITING_FOR_REPLIES_1_ON_2_WHOSE_CURRENT_MEMBERSHIP_LIST_IS_3;
    if (severeAlert) {
        logger.fatal(LocalizedMessage.create(msg, msgArgs));
    } else {
        logger.warn(LocalizedMessage.create(msg, msgArgs));
    }
    msgArgs[3] = "(omitted)";
    Breadcrumbs.setProblem(msg, msgArgs);
    // Increment the stat
    getDistributionManager().getStats().incReplyTimeouts();
    final Set suspectMembers;
    if (suspectThem || severeAlert) {
        suspectMembers = new HashSet();
    } else {
        suspectMembers = null;
    }
    synchronized (this.members) {
        for (int i = 0; i < this.members.length; i++) {
            if (this.members[i] != null) {
                if (!activeMembers.contains(this.members[i])) {
                    logger.warn(LocalizedMessage.create(LocalizedStrings.ReplyProcessor21_VIEW_NO_LONGER_HAS_0_AS_AN_ACTIVE_MEMBER_SO_WE_WILL_NO_LONGER_WAIT_FOR_IT, this.members[i]));
                    memberDeparted(this.members[i], false);
                } else {
                    if (suspectMembers != null) {
                        suspectMembers.add(this.members[i]);
                    }
                }
            }
        }
    }
    if (THROW_EXCEPTION_ON_TIMEOUT) {
        // init the cause to be a TimeoutException so catchers can determine cause
        TimeoutException cause = new TimeoutException(LocalizedStrings.TIMED_OUT_WAITING_FOR_ACKS.toLocalizedString());
        throw new InternalGemFireException(LocalizedStrings.ReplyProcessor21_0_SEC_HAVE_ELAPSED_WHILE_WAITING_FOR_REPLIES_1_ON_2_WHOSE_CURRENT_MEMBERSHIP_LIST_IS_3.toLocalizedString(msgArgs), cause);
    } else if (suspectThem) {
        if (suspectMembers != null && suspectMembers.size() > 0) {
            getDistributionManager().getMembershipManager().suspectMembers(suspectMembers, "Failed to respond within ack-wait-threshold");
        }
    }
}
Also used : Set(java.util.Set) HashSet(java.util.HashSet) StringId(org.apache.geode.i18n.StringId) InternalGemFireException(org.apache.geode.InternalGemFireException) HashSet(java.util.HashSet) TimeoutException(org.apache.geode.cache.TimeoutException)

Example 9 with StringId

use of org.apache.geode.i18n.StringId in project geode by apache.

the class PartitionedRegionDataStore method updateMemoryStats.

protected void updateMemoryStats(final long memoryDelta) {
    // Update stats
    this.partitionedRegion.getPrStats().incBytesInUse(memoryDelta);
    final long locBytes = this.bytesInUse.addAndGet(memoryDelta);
    if (!this.partitionedRegion.isEntryEvictionPossible()) {
        StringId logStr = null;
        // TODO, investigate precision issues with cast to long
        if (!this.exceededLocalMaxMemoryLimit) {
            // previously OK
            if (locBytes > this.maximumLocalBytes) {
                // not OK now
                this.exceededLocalMaxMemoryLimit = true;
                logStr = LocalizedStrings.PartitionedRegionDataStore_PARTITIONED_REGION_0_HAS_EXCEEDED_LOCAL_MAXIMUM_MEMORY_CONFIGURATION_2_MB_CURRENT_SIZE_IS_3_MB;
            }
        } else {
            if (locBytes <= this.maximumLocalBytes) {
                this.exceededLocalMaxMemoryLimit = false;
                logStr = LocalizedStrings.PartitionedRegionDataStore_PARTITIONED_REGION_0_IS_AT_OR_BELOW_LOCAL_MAXIMUM_MEMORY_CONFIGURATION_2_MB_CURRENT_SIZE_IS_3_MB;
            }
        }
        if (logStr != null) {
            Object[] logArgs = new Object[] { this.partitionedRegion.getFullPath(), logStr, Long.valueOf(this.partitionedRegion.getLocalMaxMemory()), Long.valueOf(locBytes / PartitionedRegionHelper.BYTES_PER_MB) };
            if (this.exceededLocalMaxMemoryLimit) {
                logger.warn(LocalizedMessage.create(logStr, logArgs));
            } else {
                logger.info(LocalizedMessage.create(logStr, logArgs));
            }
        }
    }
}
Also used : StringId(org.apache.geode.i18n.StringId)

Example 10 with StringId

use of org.apache.geode.i18n.StringId 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)

Aggregations

StringId (org.apache.geode.i18n.StringId)43 IOException (java.io.IOException)14 AuthorizeRequest (org.apache.geode.internal.security.AuthorizeRequest)11 LocalRegion (org.apache.geode.internal.cache.LocalRegion)10 CachedRegionHelper (org.apache.geode.internal.cache.tier.CachedRegionHelper)8 Part (org.apache.geode.internal.cache.tier.sockets.Part)8 TimeoutException (org.apache.geode.cache.TimeoutException)6 HashSet (java.util.HashSet)5 Test (org.junit.Test)5 ArrayList (java.util.ArrayList)4 List (java.util.List)4 CancelException (org.apache.geode.CancelException)4 InterestResultPolicy (org.apache.geode.cache.InterestResultPolicy)4 RegisterInterestOperationContext (org.apache.geode.cache.operations.RegisterInterestOperationContext)4 CqClosedException (org.apache.geode.cache.query.CqClosedException)4 CqException (org.apache.geode.cache.query.CqException)4 CqExistsException (org.apache.geode.cache.query.CqExistsException)4 QueryException (org.apache.geode.cache.query.QueryException)4 RegionNotFoundException (org.apache.geode.cache.query.RegionNotFoundException)4 LinkedHashSet (java.util.LinkedHashSet)3