You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@carbondata.apache.org by rahulforallp <gi...@git.apache.org> on 2018/05/03 08:51:44 UTC

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

GitHub user rahulforallp opened a pull request:

    https://github.com/apache/carbondata/pull/2262

    [CARBONDATA-2431] Incremental data added after table creation is not reflecting while doing select query issue is fixed.

    
     - [ ] Any interfaces changed? NO
     
     - [ ] Any backward compatibility impacted? NO
     
     - [ ] Document update required? NO
    
     - [ ] Testing done ==>  UT added
           
     - [ ] For large changes, please consider breaking it into sub-tasks under an umbrella JIRA.  NA
    


You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/rahulforallp/incubator-carbondata inc_load_sdk

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/carbondata/pull/2262.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #2262
    
----
commit c53522ad376885b308f50077700dabfd9fed7217
Author: rahulforallp <ra...@...>
Date:   2018-05-03T08:41:12Z

    [CARBONDATA-2431] Incremental data added after table creation is not reflecting while doing select query issue is fixed.

----


---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by asfgit <gi...@git.apache.org>.
Github user asfgit closed the pull request at:

    https://github.com/apache/carbondata/pull/2262


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4680/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5709/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5779/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4839/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4787/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5821/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187310523
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/datamap/DataMapStoreManager.java ---
    @@ -435,23 +436,30 @@ public TableSegmentRefresher getTableSegmentRefresher(CarbonTable table) {
           SegmentUpdateDetails[] updateStatusDetails = statusManager.getUpdateStatusDetails();
           for (SegmentUpdateDetails updateDetails : updateStatusDetails) {
             UpdateVO updateVO = statusManager.getInvalidTimestampRange(updateDetails.getSegmentName());
    -        segmentRefreshTime.put(updateVO.getSegmentId(), updateVO.getCreatedOrUpdatedTimeStamp());
    +        segmentRefreshTime.put(updateVO.getSegmentId(),
    +            new SegmentLatestTimestampUpdater(updateVO.getCreatedOrUpdatedTimeStamp(), 0));
           }
         }
     
    -    public boolean isRefreshNeeded(String segmentId, SegmentUpdateStatusManager statusManager) {
    -      UpdateVO updateVO = statusManager.getInvalidTimestampRange(segmentId);
    +    public boolean isRefreshNeeded(Segment seg) throws IOException {
    +      Map<String, SegmentLatestTimestampUpdater> segmentTimestampUpdaterMap =
    --- End diff --
    
    No need to use Map here, jus store SegmentLatestTimestampUpdater is enough


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5611/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4765/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5752/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Fail , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4784/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4487/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5619/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4661/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187554854
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/TableStatusReadCommittedScope.java ---
    @@ -77,6 +84,17 @@ public TableStatusReadCommittedScope(AbsoluteTableIdentifier identifier,
         return indexFiles;
       }
     
    +  public SegmentRefreshInfo getCommitedSegmentRefreshInfo(Segment segment)
    +      throws IOException {
    +    SegmentRefreshInfo segmentRefreshInfo;
    +    if (updateVo != null) {
    +      segmentRefreshInfo = new SegmentRefreshInfo(updateVo.getCreatedOrUpdatedTimeStamp(), 0);
    +    } else {
    +      segmentRefreshInfo = new SegmentRefreshInfo(0L, 0);
    +    }
    +    return segmentRefreshInfo;
    +  }
    +
    --- End diff --
    
    Add setter of CommitedSegmentRefreshInfo and set it.


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5717/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    LGTM


---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187310749
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/datamap/DataMapStoreManager.java ---
    @@ -435,23 +436,30 @@ public TableSegmentRefresher getTableSegmentRefresher(CarbonTable table) {
           SegmentUpdateDetails[] updateStatusDetails = statusManager.getUpdateStatusDetails();
           for (SegmentUpdateDetails updateDetails : updateStatusDetails) {
             UpdateVO updateVO = statusManager.getInvalidTimestampRange(updateDetails.getSegmentName());
    -        segmentRefreshTime.put(updateVO.getSegmentId(), updateVO.getCreatedOrUpdatedTimeStamp());
    +        segmentRefreshTime.put(updateVO.getSegmentId(),
    +            new SegmentLatestTimestampUpdater(updateVO.getCreatedOrUpdatedTimeStamp(), 0));
           }
         }
     
    -    public boolean isRefreshNeeded(String segmentId, SegmentUpdateStatusManager statusManager) {
    -      UpdateVO updateVO = statusManager.getInvalidTimestampRange(segmentId);
    +    public boolean isRefreshNeeded(Segment seg) throws IOException {
    +      Map<String, SegmentLatestTimestampUpdater> segmentTimestampUpdaterMap =
    +          seg.getSegmentTimestampUpdaterMap();
    +      String segmentId = seg.getSegmentNo();
           if (segmentRefreshTime.get(segmentId) == null) {
    -        segmentRefreshTime.put(segmentId, updateVO.getCreatedOrUpdatedTimeStamp());
    +        segmentRefreshTime.put(segmentId, segmentTimestampUpdaterMap.get(segmentId));
             return true;
           }
           if (manualSegmentRefresh.get(segmentId) != null && manualSegmentRefresh.get(segmentId)) {
             manualSegmentRefresh.put(segmentId, false);
             return true;
           }
    -      Long updateTimestamp = updateVO.getLatestUpdateTimestamp();
    +      Long updateTimestamp = segmentTimestampUpdaterMap.get(segmentId).getSegmentUpdatedTimestamp();
    +
           boolean isRefresh =
    -          updateTimestamp != null && (updateTimestamp > segmentRefreshTime.get(segmentId));
    +          (updateTimestamp != null && updateTimestamp > segmentRefreshTime.get(segmentId)
    --- End diff --
    
    Move this compare logic to `SegmentLatestTimestampUpdater` compare method


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by rahulforallp <gi...@git.apache.org>.
Github user rahulforallp commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    retest this please


---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r186373811
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/CommitedIndexFilesUpdatedTimestamp.java ---
    @@ -0,0 +1,73 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.carbondata.core.readcommitter;
    +
    +import java.io.Serializable;
    +import java.util.HashMap;
    +import java.util.Map;
    +
    +public class CommitedIndexFilesUpdatedTimestamp implements Serializable {
    +
    +  private Map<Long, Integer> updatedTimestampMap = new HashMap<>();
    +
    +  private static CommitedIndexFilesUpdatedTimestamp commitedIndexFilesUpdatedTimestamp =
    --- End diff --
    
    Directly pass this object to SegmentRefresher, there it will be cached. No need to cache here


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4567/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4712/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4749/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4884/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5815/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4723/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4556/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r186373935
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/CommitedIndexFilesUpdatedTimestamp.java ---
    @@ -0,0 +1,73 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.carbondata.core.readcommitter;
    +
    +import java.io.Serializable;
    +import java.util.HashMap;
    +import java.util.Map;
    +
    +public class CommitedIndexFilesUpdatedTimestamp implements Serializable {
    +
    +  private Map<Long, Integer> updatedTimestampMap = new HashMap<>();
    +
    +  private static CommitedIndexFilesUpdatedTimestamp commitedIndexFilesUpdatedTimestamp =
    +      new CommitedIndexFilesUpdatedTimestamp();
    +
    +  public static CommitedIndexFilesUpdatedTimestamp getInstance() {
    +    return commitedIndexFilesUpdatedTimestamp;
    +  }
    +
    +  public Map<Long, Integer> getUpdatedTimestampMap() {
    +    return updatedTimestampMap;
    +  }
    +
    +  public void addUpdatedTimestampMap(Long timestampMap) {
    --- End diff --
    
    Use constructor, don't use setters


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4545/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4665/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5776/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4872/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187553518
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/TableStatusReadCommittedScope.java ---
    @@ -37,6 +39,7 @@
     public class TableStatusReadCommittedScope implements ReadCommittedScope {
     
       private LoadMetadataDetails[] loadMetadataDetails;
    +  UpdateVO updateVo;
    --- End diff --
    
    Make it private


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5647/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4509/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5728/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4793/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4560/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4700/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4555/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5812/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5681/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r186374044
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/CommitedIndexFilesUpdatedTimestamp.java ---
    @@ -0,0 +1,73 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.carbondata.core.readcommitter;
    +
    +import java.io.Serializable;
    +import java.util.HashMap;
    +import java.util.Map;
    +
    +public class CommitedIndexFilesUpdatedTimestamp implements Serializable {
    +
    +  private Map<Long, Integer> updatedTimestampMap = new HashMap<>();
    +
    +  private static CommitedIndexFilesUpdatedTimestamp commitedIndexFilesUpdatedTimestamp =
    +      new CommitedIndexFilesUpdatedTimestamp();
    +
    +  public static CommitedIndexFilesUpdatedTimestamp getInstance() {
    +    return commitedIndexFilesUpdatedTimestamp;
    +  }
    +
    +  public Map<Long, Integer> getUpdatedTimestampMap() {
    +    return updatedTimestampMap;
    +  }
    +
    +  public void addUpdatedTimestampMap(Long timestampMap) {
    +    Integer c = updatedTimestampMap.get(timestampMap);
    +    if (c == null) {
    +      updatedTimestampMap.put(timestampMap, 1);
    +    } else {
    +      updatedTimestampMap.put(timestampMap, c + 1);
    +    }
    +  }
    +
    +  public void reset() {
    +    this.updatedTimestampMap = new HashMap<>();
    +  }
    +
    +  @Override public boolean equals(Object o) {
    +    if (this == o) return true;
    +    if (!(o instanceof CommitedIndexFilesUpdatedTimestamp)) return false;
    +
    +    CommitedIndexFilesUpdatedTimestamp that = (CommitedIndexFilesUpdatedTimestamp) o;
    +
    +    return updatedTimestampMap.equals(that.updatedTimestampMap);
    +  }
    +
    +  @Override public int hashCode() {
    +    return updatedTimestampMap.hashCode();
    +  }
    +
    +  public CommitedIndexFilesUpdatedTimestamp getClone() {
    --- End diff --
    
    It is not needed, create new object every time


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4450/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by rahulforallp <gi...@git.apache.org>.
GitHub user rahulforallp reopened a pull request:

    https://github.com/apache/carbondata/pull/2262

    [CARBONDATA-2431] Incremental data added after external table creation is not reflecting while doing select query issue is fixed.

    
     - [x] Any interfaces changed? NO
     
     - [x] Any backward compatibility impacted? NO
     
     - [x] Document update required? NO
    
     - [x] Testing done ==>  UT added
           
     - [x] For large changes, please consider breaking it into sub-tasks under an umbrella JIRA.  NA
    


You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/rahulforallp/incubator-carbondata inc_load_sdk

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/carbondata/pull/2262.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #2262
    
----
commit ee429388cee55bed5aa2876548c645037860ba2c
Author: rahulforallp <ra...@...>
Date:   2018-05-03T08:41:12Z

    [CARBONDATA-2431] Incremental data added after table creation is not reflecting while doing select query issue is fixed.

----


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5688/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4786/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4528/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4631/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187312611
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/LatestFilesReadCommittedScope.java ---
    @@ -134,18 +152,29 @@ private String getSegmentID(String carbonIndexFileName, String indexFilePath) {
                   getSegmentID(carbonIndexFiles[i].getName(), carbonIndexFiles[i].getAbsolutePath());
               // TODO. During Partition table handling, place Segment File Name.
               List<String> indexList;
    +          SegmentLatestTimestampUpdater segmentLatestTimestampUpdater;
               if (indexFileStore.get(segId) == null) {
                 indexList = new ArrayList<>(1);
    +            segmentLatestTimestampUpdater =
    +                new SegmentLatestTimestampUpdater(carbonIndexFiles[i].getLastModifiedTime(), 0);
               } else {
                 // Entry is already present.
                 indexList = indexFileStore.get(segId);
    +            segmentLatestTimestampUpdater = segmentTimestampUpdaterMap.get(segId);
               }
               indexList.add(carbonIndexFiles[i].getAbsolutePath());
    +          if (segmentLatestTimestampUpdater.getSegmentUpdatedTimestamp() < carbonIndexFiles[i]
    +              .getLastModifiedTime()) {
    +            segmentLatestTimestampUpdater
    +                .setSegmentUpdatedTimestamp(carbonIndexFiles[i].getLastModifiedTime());
    +          }
               indexFileStore.put(segId, indexList);
    +          segmentLatestTimestampUpdater.setCountOfFileInSegment(indexList.size());
    +          segmentTimestampUpdaterMap.put(segId, segmentLatestTimestampUpdater);
    --- End diff --
    
    this line move to 159


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5786/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5738/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4621/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5670/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187555918
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/TableStatusReadCommittedScope.java ---
    @@ -77,6 +84,17 @@ public TableStatusReadCommittedScope(AbsoluteTableIdentifier identifier,
         return indexFiles;
       }
     
    +  public SegmentRefreshInfo getCommitedSegmentRefreshInfo(Segment segment)
    --- End diff --
    
    Add another argument to pass UpdateVo


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Fail , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4871/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by rahulforallp <gi...@git.apache.org>.
Github user rahulforallp commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    retest this please


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4658/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5607/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5836/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187376048
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/TableStatusReadCommittedScope.java ---
    @@ -77,6 +78,12 @@ public TableStatusReadCommittedScope(AbsoluteTableIdentifier identifier,
         return indexFiles;
       }
     
    +  public Map<String, SegmentRefreshInfo> getCommitedSegmentTimestampUpdaterMap(
    +      Segment segment) throws IOException {
    +    Map<String, SegmentRefreshInfo> indexFiles = new HashMap<>();
    +    return indexFiles;
    --- End diff --
    
    It should return only SegmentRefreshInfo object not Map.
    And it should be fillied with updateVo timestamp.


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4863/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4672/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r186372903
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/CommitedIndexFilesUpdatedTimestamp.java ---
    @@ -0,0 +1,73 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.carbondata.core.readcommitter;
    +
    +import java.io.Serializable;
    +import java.util.HashMap;
    +import java.util.Map;
    +
    +public class CommitedIndexFilesUpdatedTimestamp implements Serializable {
    +
    +  private Map<Long, Integer> updatedTimestampMap = new HashMap<>();
    --- End diff --
    
    It always has 2 attributes, not a map,
    1. timestamp : It has max modified time across all files in a segment.
    2. count.: the total number of files in a segment.



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4446/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by rahulforallp <gi...@git.apache.org>.
Github user rahulforallp commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    retest this please


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4459/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4593/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4799/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5716/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187309701
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/datamap/DataMapStoreManager.java ---
    @@ -424,7 +425,7 @@ public TableSegmentRefresher getTableSegmentRefresher(CarbonTable table) {
     
         // This map stores the latest segment refresh time.So in case of update/delete we check the
         // time against this map.
    -    private Map<String, Long> segmentRefreshTime = new HashMap<>();
    +    private Map<String, SegmentLatestTimestampUpdater> segmentRefreshTime = new HashMap<>();
    --- End diff --
    
    Better rename as `SegmentRefreshInfo`


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5721/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by rahulforallp <gi...@git.apache.org>.
Github user rahulforallp closed the pull request at:

    https://github.com/apache/carbondata/pull/2262


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5708/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by rahulforallp <gi...@git.apache.org>.
Github user rahulforallp commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    retest this please


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5672/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5828/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4580/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Success with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4521/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r186369605
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/CommitedIndexFilesUpdatedTimestamp.java ---
    @@ -0,0 +1,73 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.carbondata.core.readcommitter;
    +
    +import java.io.Serializable;
    +import java.util.HashMap;
    +import java.util.Map;
    +
    +public class CommitedIndexFilesUpdatedTimestamp implements Serializable {
    --- End diff --
    
    Better rename something like SegmentModifyUpdater


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4748/



---

[GitHub] carbondata pull request #2262: [CARBONDATA-2431] Incremental data added afte...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/2262#discussion_r187314011
  
    --- Diff: core/src/main/java/org/apache/carbondata/core/readcommitter/TableStatusReadCommittedScope.java ---
    @@ -77,6 +78,12 @@ public TableStatusReadCommittedScope(AbsoluteTableIdentifier identifier,
         return indexFiles;
       }
     
    +  public Map<String, SegmentLatestTimestampUpdater> getCommitedSegmentTimestampUpdaterMap(
    --- End diff --
    
    You should not return empty map here. You should pass updateManager through constructor and get the update timestamp from it and return new SegmentLatestTimestampUpdater


---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4547/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed with Spark 2.2.1, Please check CI http://88.99.58.216:8080/job/ApacheCarbonPRBuilder/4512/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4867/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4830/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by ravipesala <gi...@git.apache.org>.
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/4788/



---

[GitHub] carbondata issue #2262: [CARBONDATA-2431] Incremental data added after exter...

Posted by CarbonDataQA <gi...@git.apache.org>.
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/2262
  
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/5706/



---