You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@cassandra.apache.org by André Fiedler <fi...@googlemail.com> on 2010/11/16 21:38:10 UTC

Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

I try to perform the following action after a clean startup. And get the log
below. How to fix this?

------------------------- Action ------------------------------

   create column family Test with comparator=LexicalUUIDType and
column_metadata=[

    {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
index_name:test1},

    {column_name:test2, validation_class:UTF8Type, index_type:0,
index_name:test2},

    {column_name:test3, validation_class:UTF8Type},

    {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
index_name:test4},

    {column_name:test5, validation_class:BytesType, index_type:0,
index_name:test5},

    {column_name:test6, validation_class:BytesType, index_type:0,
index_name:test6},

    {column_name:test7, validation_class:LongType, index_type:0,
index_name:test7},

    {column_name:test8, validation_class:BytesType, index_type:0,
index_name:test8},

    {column_name:test9, validation_class:UTF8Type},

    {column_name:test10, validation_class:LongType},

    {column_name:test11, validation_class:UTF8Type},

    {column_name:test12, validation_class:LongType},

    {column_name:test13, validation_class:LongType},

    {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
index_name:test14}

]


------------------------- Log ------------------------------

 INFO 21:30:40,004 Heap size: 1069416448/1069416448
 INFO 21:30:40,098 JNA not found. Native methods will be disabled.
 INFO 21:30:40,151 Loading settings from
file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
 INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
indexAccessMode is mmap
 INFO 21:30:40,822 Creating new commitlog segment
/var/lib/cassandra/commitlog/CommitLog-1289939440822.log
 INFO 21:30:40,944 read 0 from saved key cache
 INFO 21:30:40,949 read 0 from saved key cache
 INFO 21:30:40,950 read 0 from saved key cache
 INFO 21:30:40,952 read 0 from saved key cache
 INFO 21:30:40,953 read 0 from saved key cache
 INFO 21:30:41,007 loading row cache for LocationInfo of system
 INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
LocationInfo of system
 INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
 INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
HintsColumnFamily of system
 INFO 21:30:41,010 loading row cache for Migrations of system
 INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
Migrations of system
 INFO 21:30:41,014 loading row cache for Schema of system
 INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema of
system
 INFO 21:30:41,015 loading row cache for IndexInfo of system
 INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for IndexInfo
of system
 INFO 21:30:41,121 Couldn't detect any schema definitions in local storage.
 INFO 21:30:41,123 Found table data in data directories. Consider using JMX
to call org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
 INFO 21:30:41,126 No commitlog files found; skipping replay
 INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
hints will be snapshotted.
 INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
 INFO 21:30:41,224 Thrift API version: 19.4.0
 INFO 21:30:41,240 Loading persisted ring state
 INFO 21:30:41,251 Starting up server gossip
 INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=700)
 INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
bytes, 4 operations)
 INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4
operations)
 INFO 21:30:41,536 Completed flushing
/var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
 WARN 21:30:41,622 Generated random token
77213727368801109223786819704694530797. Random tokens will result in an
unbalanced ring; see http://wiki.apache.org/cassandra/Operations
 INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=848)
 INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
bytes, 1 operations)
 INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
operations)
 INFO 21:30:41,717 Completed flushing
/var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
 INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
classpath
 INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
 INFO 21:30:41,828 Using TFramedTransport with a max frame size of 15728640
bytes.
 INFO 21:30:41,850 Listening for thrift clients...
 INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=11605)
 INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
bytes, 1 operations)
 INFO 21:31:20,386 switching in a fresh Memtable for Schema at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=11605)
 INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184 bytes,
3 operations)
 INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
operations)
 INFO 21:31:20,532 Completed flushing
/var/lib/cassandra/data/system/Migrations-e-1-Data.db
 INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
operations)
 INFO 21:31:20,627 Completed flushing
/var/lib/cassandra/data/system/Schema-e-1-Data.db
 INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=24059)
 INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
bytes, 1 operations)
 INFO 21:31:26,557 switching in a fresh Memtable for Schema at
CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
position=24059)
 INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
operations)
 INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131 bytes,
3 operations)
 INFO 21:31:26,651 Completed flushing
/var/lib/cassandra/data/system/Migrations-e-2-Data.db
 INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
operations)
 INFO 21:31:26,764 Completed flushing
/var/lib/cassandra/data/system/Schema-e-2-Data.db
 INFO 21:31:26,767 read 0 from saved key cache
 INFO 21:31:26,770 read 0 from saved key cache
 INFO 21:31:26,770 Creating index
org.apache.cassandra.db.Table@7e7f8062.Test.test1
ERROR 21:31:26,808 Fatal exception in thread Thread[MigrationStage:1,5,main]
java.lang.IndexOutOfBoundsException
at java.nio.Buffer.checkIndex(Buffer.java:520)
at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
 at
org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
at
org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
 at
org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
at
java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
 at
java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
at
java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
 at
org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
at
org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
 at
org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
at
org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
 at
org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
at
org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
 at org.apache.cassandra.db.Table.initCf(Table.java:335)
at
org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
 at org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
at
org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
 at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
at java.util.concurrent.FutureTask.run(FutureTask.java:138)
 at
java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
 at java.lang.Thread.run(Thread.java:680)
ERROR 21:31:26,809 Thrift error occurred during processing of message.
org.apache.thrift.protocol.TProtocolException: Required field 'why' was not
present! Struct: InvalidRequestException(why:null)
 at
org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
at
org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
 at
org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
at
org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
 at
org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
at
org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
 at
java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
 at java.lang.Thread.run(Thread.java:680)

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by André Fiedler <fi...@googlemail.com>.
Ah ok, i thougt the comparator is used to compare CF keys... now the
exception makes sense to me. Thx! :o)


2010/11/16 Aaron Morton <aa...@thelastpickle.com>

> Your CF meta data says the column names are UUID's
> (comparator=LexicalUUIDType) but your column_metadata says the name of one
> of the columns is "test1" (and test2 etc). This is not a valid UUID.
>
> Either change the comparator or use UUID's for the column names in the
> column_metadata.
>
>
> Aaron
>
>
> On 17 Nov, 2010,at 10:29 AM, André Fiedler <fi...@googlemail.com>
> wrote:
>
> Ah ok, didn´t know that. Now it starts up, but throws a new exception:
>
> ------------------------- Log ------------------------------
>
> [default@Test] create column family Test with comparator=LexicalUUIDType
> and column_metadata=[{column_name:test1, validation_class:LexicalUUIDType,
> index_type:0, index_name:test1},{column_name:test2,
> validation_class:UTF8Type, index_type:0,
> index_name:test2},{column_name:test3,
> validation_class:UTF8Type},{column_name:test4,
> validation_class:LexicalUUIDType, index_type:0,
> index_name:test4},{column_name:test5, validation_class:BytesType,
> index_type:0, index_name:test5},{column_name:test6,
> validation_class:BytesType, index_type:0,
> index_name:test6},{column_name:test7, validation_class:LongType,
> index_type:0, index_name:test7},{column_name:test8,
> validation_class:BytesType, index_type:0,
> index_name:test8},{column_name:test9,
> validation_class:UTF8Type},{column_name:test10,
> validation_class:LongType},{column_name:test11,
> validation_class:UTF8Type},{column_name:test12,
> validation_class:LongType},{column_name:test13,
> validation_class:LongType},{column_name:test14,
> validation_class:LexicalUUIDType, index_type:0, index_name:test14}]
> Invalid UUID string: test1
> [default@Test]
>
>
> 2010/11/16 Aaron Morton <aa...@thelastpickle.com>
>
>> did you do a clean and then build ? "ant clean" then "ant jar"
>>
>> Aaron
>>
>>
>>
>> On 17 Nov, 2010,at 10:10 AM, André Fiedler <fi...@googlemail.com>
>> wrote:
>>
>>
>> Latest branch doesn´t start:
>>
>> ------------------------- Log ------------------------------
>>
>>
>> Exception in thread "main" java.lang.NoClassDefFoundError:
>> org/apache/cassandra/thrift/CassandraDaemon
>> Caused by: java.lang.ClassNotFoundException:
>> org.apache.cassandra.thrift.CassandraDaemon
>> at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
>>  at java.security.AccessController.doPrivileged(Native Method)
>> at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
>>  at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
>> at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
>>  at java.lang.ClassLoader.loadClass(ClassLoader.java:248)
>>
>>
>>
>>
>> 2010/11/16 André Fiedler <fi...@googlemail.com>
>>
>>>
>>> Thx! :o) so i will do
>>>
>>>
>>> 2010/11/16 Jake Luciani <ja...@gmail.com>
>>>
>>>
>>>
>>>> This is a bug in beta3, if you checkout the cassandra-0.7 branch it
>>>> should work for you.
>>>>
>>>>
>>>>
>>>>
>>>> On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <
>>>> fiedler.andre@googlemail.com> wrote:
>>>>
>>>>>
>>>>> I try to perform the following action after a clean startup. And get
>>>>> the log below. How to fix this?
>>>>>
>>>>> ------------------------- Action ------------------------------
>>>>>
>>>>>
>>>>> create column family Test with comparator=LexicalUUIDType and
>>>>> column_metadata=[
>>>>>
>>>>>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
>>>>> index_name:test1},
>>>>>
>>>>>     {column_name:test2, validation_class:UTF8Type, index_type:0,
>>>>> index_name:test2},
>>>>>
>>>>>     {column_name:test3, validation_class:UTF8Type},
>>>>>
>>>>>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
>>>>> index_name:test4},
>>>>>
>>>>>     {column_name:test5, validation_class:BytesType, index_type:0,
>>>>> index_name:test5},
>>>>>
>>>>>     {column_name:test6, validation_class:BytesType, index_type:0,
>>>>> index_name:test6},
>>>>>
>>>>>     {column_name:test7, validation_class:LongType, index_type:0,
>>>>> index_name:test7},
>>>>>
>>>>>     {column_name:test8, validation_class:BytesType, index_type:0,
>>>>> index_name:test8},
>>>>>
>>>>>     {column_name:test9, validation_class:UTF8Type},
>>>>>
>>>>>     {column_name:test10, validation_class:LongType},
>>>>>
>>>>>     {column_name:test11, validation_class:UTF8Type},
>>>>>
>>>>>     {column_name:test12, validation_class:LongType},
>>>>>
>>>>>     {column_name:test13, validation_class:LongType},
>>>>>
>>>>>     {column_name:test14, validation_class:LexicalUUIDType,
>>>>> index_type:0, index_name:test14}
>>>>>
>>>>> ]
>>>>>
>>>>>
>>>>> ------------------------- Log ------------------------------
>>>>>
>>>>>
>>>>>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>>>>>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>>>>>  INFO 21:30:40,151 Loading settings from
>>>>> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>>>>>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
>>>>> indexAccessMode is mmap
>>>>>  INFO 21:30:40,822 Creating new commitlog segment
>>>>> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>>>>>  INFO 21:30:40,944 read 0 from saved key cache
>>>>>  INFO 21:30:40,949 read 0 from saved key cache
>>>>>  INFO 21:30:40,950 read 0 from saved key cache
>>>>>  INFO 21:30:40,952 read 0 from saved key cache
>>>>>  INFO 21:30:40,953 read 0 from saved key cache
>>>>>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>>>>>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
>>>>> LocationInfo of system
>>>>>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>>>>>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
>>>>> HintsColumnFamily of system
>>>>>  INFO 21:30:41,010 loading row cache for Migrations of system
>>>>>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
>>>>> Migrations of system
>>>>>  INFO 21:30:41,014 loading row cache for Schema of system
>>>>>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for
>>>>> Schema of system
>>>>>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>>>>>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
>>>>> IndexInfo of system
>>>>>  INFO 21:30:41,121 Couldn't detect any schema definitions in local
>>>>> storage.
>>>>>  INFO 21:30:41,123 Found table data in data directories. Consider using
>>>>> JMX to call orgapache.cassandra.service.StorageService.loadSchemaFromYaml().
>>>>>
>>>>>  INFO 21:30:41,126 No commitlog files found; skipping replay
>>>>>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any.
>>>>> Old hints will be snapshotted.
>>>>>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>>>>>  INFO 21:30:41,224 Thrift API version: 19.4.0
>>>>>  INFO 21:30:41,240 Loading persisted ring state
>>>>>  INFO 21:30:41,251 Starting up server gossip
>>>>>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=700)
>>>>>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
>>>>> bytes, 4 operations)
>>>>>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes,
>>>>> 4 operations)
>>>>>  INFO 21:30:41,536 Completed flushing
>>>>> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>>>>>  WARN 21:30:41,622 Generated random token
>>>>> 77213727368801109223786819704694530797. Random tokens will result in an
>>>>> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>>>>>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=848)
>>>>>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
>>>>> bytes, 1 operations)
>>>>>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
>>>>> operations)
>>>>>  INFO 21:30:41,717 Completed flushing
>>>>> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>>>>>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
>>>>> classpath
>>>>>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160<http://127.00.1:9160>
>>>>>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of
>>>>> 15728640 bytes.
>>>>>  INFO 21:30:41,850 Listening for thrift clients...
>>>>>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=11605)
>>>>>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
>>>>> bytes, 1 operations)
>>>>>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=11605)
>>>>>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
>>>>> bytes, 3 operations)
>>>>>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes,
>>>>> 1 operations)
>>>>>  INFO 21:31:20,532 Completed flushing
>>>>> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>>>>>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
>>>>> operations)
>>>>>  INFO 21:31:20,627 Completed flushing
>>>>> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>>>>>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=24059)
>>>>>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
>>>>> bytes, 1 operations)
>>>>>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
>>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>>> position=24059)
>>>>>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes,
>>>>> 1 operations)
>>>>>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
>>>>> bytes, 3 operations)
>>>>>  INFO 21:31:26,651 Completed flushing
>>>>> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>>>>>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
>>>>> operations)
>>>>>  INFO 21:31:26,764 Completed flushing
>>>>> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>>>>>  INFO 21:31:26,767 read 0 from saved key cache
>>>>>  INFO 21:31:26,770 read 0 from saved key cache
>>>>>  INFO 21:31:26,770 Creating index
>>>>> org.apache.cassandra.db.Table@7e7f8062.Test.test1
>>>>> ERROR 21:31:26,808 Fatal exception in thread
>>>>> Thread[MigrationStage:1,5,main]
>>>>> java.lang.IndexOutOfBoundsException
>>>>> at java.nio.Buffer.checkIndex(Buffer.java:520)
>>>>> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>>>>>  at
>>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
>>>>> at
>>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>>>>>  at
>>>>> orgapache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
>>>>> at
>>>>> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>>>>>  at
>>>>> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
>>>>> at
>>>>> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>>>>>  at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
>>>>> at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>>>>>  at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
>>>>> at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>>>>>  at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
>>>>> at
>>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>>>>>  at org.apache.cassandra.db.TableinitCf(Table.java:335)
>>>>> at
>>>>> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>>>>>  at
>>>>> org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
>>>>> at
>>>>> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>>>>>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
>>>>> at javautil.concurrent.FutureTask.run(FutureTask.java:138)
>>>>>  at
>>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>>> at
>>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>>  at java.lang.Thread.run(Thread.java:680)
>>>>> ERROR 21:31:26,809 Thrift error occurred during processing of message.
>>>>> org.apache.thrift.protocol.TProtocolException: Required field 'why' was
>>>>> not present! Struct: InvalidRequestException(why:null)
>>>>>  at
>>>>> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
>>>>> at
>>>>> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>>>>>  at
>>>>> org.apache.cassandra.thrift.Cassandra$system_add_column_family_resultwrite(Cassandra.java:23401)
>>>>> at
>>>>> org.apachecassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>>>>>  at
>>>>> org.apachecassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
>>>>> at
>>>>> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>>>>>  at
>>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>>> at
>>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>>  at javalang.Thread.run(Thread.java:680)
>>>>>
>>>>>
>>>>>
>>>>
>>>
>>
>

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by Aaron Morton <aa...@thelastpickle.com>.
Your CF meta data says the column names are UUID's (comparator=LexicalUUIDType) but your column_metadata says the name of one of the columns is "test1" (and test2 etc). This is not a valid UUID. 

Either change the comparator or use UUID's for the column names in the column_metadata. 
 

Aaron


On 17 Nov, 2010,at 10:29 AM, André Fiedler <fi...@googlemail.com> wrote:

Ah ok, didn´t know that. Now it starts up, but throws a new exception:

------------------------- Log ------------------------------

[default@Test] create column family Test with comparator=LexicalUUIDType and column_metadata=[{column_name:test1, validation_class:LexicalUUIDType, index_type:0, index_name:test1},{column_name:test2, validation_class:UTF8Type, index_type:0, index_name:test2},{column_name:test3, validation_class:UTF8Type},{column_name:test4, validation_class:LexicalUUIDType, index_type:0, index_name:test4},{column_name:test5, validation_class:BytesType, index_type:0, index_name:test5},{column_name:test6, validation_class:BytesType, index_type:0, index_name:test6},{column_name:test7, validation_class:LongType, index_type:0, index_name:test7},{column_name:test8, validation_class:BytesType, index_type:0, index_name:test8},{column_name:test9, validation_class:UTF8Type},{column_name:test10, validation_class:LongType},{column_name:test11, validation_class:UTF8Type},{column_name:test12, validation_class:LongType},{column_name:test13, validation_class:LongType},{column_name:test14, validation_class:LexicalUUIDType, index_type:0, index_name:test14}]
Invalid UUID string: test1
[default@Test] 


2010/11/16 Aaron Morton <aa...@thelastpickle.com>
did you do a clean and then build ? "ant clean" then "ant jar"

Aaron



On 17 Nov, 2010,at 10:10 AM, André Fiedler <fi...@googlemail.com> wrote:


Latest branch doesn´t start:

------------------------- Log ------------------------------


Exception in thread "main" java.lang.NoClassDefFoundError: org/apache/cassandra/thrift/CassandraDaemon
Caused by: java.lang.ClassNotFoundException: org.apache.cassandra.thrift.CassandraDaemon
	at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
	at java.security.AccessController.doPrivileged(Native Method)
	at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
	at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
	at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
	at java.lang.ClassLoader.loadClass(ClassLoader.java:248)




2010/11/16 André Fiedler <fi...@googlemail.com>

Thx! :o) so i will do


2010/11/16 Jake Luciani <ja...@gmail.com>



This is a bug in beta3, if you checkout the cassandra-0.7 branch it should work for you.




On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <fi...@googlemail.com> wrote:

I try to perform the following action after a clean startup. And get the log below. How to fix this?

------------------------- Action ------------------------------


create column family Test with comparator=LexicalUUIDType and column_metadata=[
    {column_name:test1, validation_class:LexicalUUIDType, index_type:0, index_name:test1},
    {column_name:test2, validation_class:UTF8Type, index_type:0, index_name:test2},
    {column_name:test3, validation_class:UTF8Type},
    {column_name:test4, validation_class:LexicalUUIDType, index_type:0, index_name:test4},
    {column_name:test5, validation_class:BytesType, index_type:0, index_name:test5},
    {column_name:test6, validation_class:BytesType, index_type:0, index_name:test6},
    {column_name:test7, validation_class:LongType, index_type:0, index_name:test7},
    {column_name:test8, validation_class:BytesType, index_type:0, index_name:test8},
    {column_name:test9, validation_class:UTF8Type},
    {column_name:test10, validation_class:LongType},
    {column_name:test11, validation_class:UTF8Type},
    {column_name:test12, validation_class:LongType},
    {column_name:test13, validation_class:LongType},
    {column_name:test14, validation_class:LexicalUUIDType, index_type:0, index_name:test14}
]

------------------------- Log ------------------------------


 INFO 21:30:40,004 Heap size: 1069416448/1069416448
 INFO 21:30:40,098 JNA not found. Native methods will be disabled.
 INFO 21:30:40,151 Loading settings from file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
 INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap, indexAccessMode is mmap
 INFO 21:30:40,822 Creating new commitlog segment /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
 INFO 21:30:40,944 read 0 from saved key cache
 INFO 21:30:40,949 read 0 from saved key cache
 INFO 21:30:40,950 read 0 from saved key cache
 INFO 21:30:40,952 read 0 from saved key cache
 INFO 21:30:40,953 read 0 from saved key cache
 INFO 21:30:41,007 loading row cache for LocationInfo of system
 INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for LocationInfo of system
 INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
 INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for HintsColumnFamily of system
 INFO 21:30:41,010 loading row cache for Migrations of system
 INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for Migrations of system
 INFO 21:30:41,014 loading row cache for Schema of system
 INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema of system
 INFO 21:30:41,015 loading row cache for IndexInfo of system
 INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for IndexInfo of system
 INFO 21:30:41,121 Couldn't detect any schema definitions in local storage.
 INFO 21:30:41,123 Found table data in data directories. Consider using JMX to call orgapache.cassandra.service.StorageService.loadSchemaFromYaml().

 INFO 21:30:41,126 No commitlog files found; skipping replay
 INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old hints will be snapshotted.
 INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
 INFO 21:30:41,224 Thrift API version: 19.4.0
 INFO 21:30:41,240 Loading persisted ring state
 INFO 21:30:41,251 Starting up server gossip
 INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=700)
 INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227 bytes, 4 operations)
 INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4 operations)
 INFO 21:30:41,536 Completed flushing /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
 WARN 21:30:41,622 Generated random token 77213727368801109223786819704694530797. Random tokens will result in an unbalanced ring; see http://wiki.apache.org/cassandra/Operations
 INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=848)
 INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36 bytes, 1 operations)
 INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1 operations)
 INFO 21:30:41,717 Completed flushing /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
 INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the classpath
 INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
 INFO 21:30:41,828 Using TFramedTransport with a max frame size of 15728640 bytes.
 INFO 21:30:41,850 Listening for thrift clients...
 INFO 21:31:20,385 switching in a fresh Memtable for Migrations at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=11605)
 INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082 bytes, 1 operations)
 INFO 21:31:20,386 switching in a fresh Memtable for Schema at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=11605)
 INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184 bytes, 3 operations)
 INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1 operations)
 INFO 21:31:20,532 Completed flushing /var/lib/cassandra/data/system/Migrations-e-1-Data.db
 INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3 operations)
 INFO 21:31:20,627 Completed flushing /var/lib/cassandra/data/system/Schema-e-1-Data.db
 INFO 21:31:26,556 switching in a fresh Memtable for Migrations at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=24059)
 INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927 bytes, 1 operations)
 INFO 21:31:26,557 switching in a fresh Memtable for Schema at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=24059)
 INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1 operations)
 INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131 bytes, 3 operations)
 INFO 21:31:26,651 Completed flushing /var/lib/cassandra/data/system/Migrations-e-2-Data.db
 INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3 operations)
 INFO 21:31:26,764 Completed flushing /var/lib/cassandra/data/system/Schema-e-2-Data.db
 INFO 21:31:26,767 read 0 from saved key cache
 INFO 21:31:26,770 read 0 from saved key cache
 INFO 21:31:26,770 Creating index org.apache.cassandra.db.Table@7e7f8062.Test.test1
ERROR 21:31:26,808 Fatal exception in thread Thread[MigrationStage:1,5,main]
javalang.IndexOutOfBoundsException
	at java.nio.Buffer.checkIndex(Buffer.java:520)
	at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDTypejava:37)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
	at java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
	at java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
	at java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
	at org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
	at org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStorejava:351)
	at org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
	at org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
	at org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
	at org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
	at org.apache.cassandra.db.TableinitCf(Table.java:335)
	at org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
	at org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
	at org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
	at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
	at java.util.concurrent.FutureTask.run(FutureTaskjava:138)
	at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
	at java.lang.Thread.run(Thread.java:680)
ERROR 21:31:26,809 Thrift error occurred during processing of message.
org.apache.thrift.protocol.TProtocolException: Required field 'why' was not present! Struct: InvalidRequestException(why:null)
	at org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
	at org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
	at org.apache.cassandra.thrift.Cassandra$system_add_column_family_resultwrite(Cassandra.java:23401)
	at org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
	at org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
	at org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
	at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
	at javalang.Thread.run(Thread.java:680)







Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by André Fiedler <fi...@googlemail.com>.
Ah ok, didn´t know that. Now it starts up, but throws a new exception:

------------------------- Log ------------------------------

[default@Test] create column family Test with comparator=LexicalUUIDType and
column_metadata=[{column_name:test1, validation_class:LexicalUUIDType,
index_type:0, index_name:test1},{column_name:test2,
validation_class:UTF8Type, index_type:0,
index_name:test2},{column_name:test3,
validation_class:UTF8Type},{column_name:test4,
validation_class:LexicalUUIDType, index_type:0,
index_name:test4},{column_name:test5, validation_class:BytesType,
index_type:0, index_name:test5},{column_name:test6,
validation_class:BytesType, index_type:0,
index_name:test6},{column_name:test7, validation_class:LongType,
index_type:0, index_name:test7},{column_name:test8,
validation_class:BytesType, index_type:0,
index_name:test8},{column_name:test9,
validation_class:UTF8Type},{column_name:test10,
validation_class:LongType},{column_name:test11,
validation_class:UTF8Type},{column_name:test12,
validation_class:LongType},{column_name:test13,
validation_class:LongType},{column_name:test14,
validation_class:LexicalUUIDType, index_type:0, index_name:test14}]
Invalid UUID string: test1
[default@Test]


2010/11/16 Aaron Morton <aa...@thelastpickle.com>

> did you do a clean and then build ? "ant clean" then "ant jar"
>
> Aaron
>
>
> On 17 Nov, 2010,at 10:10 AM, André Fiedler <fi...@googlemail.com>
> wrote:
>
> Latest branch doesn´t start:
>
> ------------------------- Log ------------------------------
>
> Exception in thread "main" java.lang.NoClassDefFoundError:
> org/apache/cassandra/thrift/CassandraDaemon
> Caused by: java.lang.ClassNotFoundException:
> org.apache.cassandra.thrift.CassandraDaemon
> at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
>  at java.security.AccessController.doPrivileged(Native Method)
> at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
>  at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
> at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
>  at java.lang.ClassLoader.loadClass(ClassLoader.java:248)
>
>
>
> 2010/11/16 André Fiedler <fi...@googlemail.com>
>
>> Thx! :o) so i will do
>>
>> 2010/11/16 Jake Luciani <ja...@gmail.com>
>>
>>
>> This is a bug in beta3, if you checkout the cassandra-0.7 branch it should
>>> work for you.
>>>
>>>
>>>
>>> On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <
>>> fiedler.andre@googlemail.com> wrote:
>>>
>>>> I try to perform the following action after a clean startup. And get the
>>>> log below. How to fix this?
>>>>
>>>> ------------------------- Action ------------------------------
>>>>
>>>> create column family Test with comparator=LexicalUUIDType and
>>>> column_metadata=[
>>>>
>>>>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test1},
>>>>
>>>>     {column_name:test2, validation_class:UTF8Type, index_type:0,
>>>> index_name:test2},
>>>>
>>>>     {column_name:test3, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test4},
>>>>
>>>>     {column_name:test5, validation_class:BytesType, index_type:0,
>>>> index_name:test5},
>>>>
>>>>     {column_name:test6, validation_class:BytesType, index_type:0,
>>>> index_name:test6},
>>>>
>>>>     {column_name:test7, validation_class:LongType, index_type:0,
>>>> index_name:test7},
>>>>
>>>>     {column_name:test8, validation_class:BytesType, index_type:0,
>>>> index_name:test8},
>>>>
>>>>     {column_name:test9, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test10, validation_class:LongType},
>>>>
>>>>     {column_name:test11, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test12, validation_class:LongType},
>>>>
>>>>     {column_name:test13, validation_class:LongType},
>>>>
>>>>     {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test14}
>>>>
>>>> ]
>>>>
>>>>
>>>> ------------------------- Log ------------------------------
>>>>
>>>>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>>>>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>>>>  INFO 21:30:40,151 Loading settings from
>>>> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>>>>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
>>>> indexAccessMode is mmap
>>>>  INFO 21:30:40,822 Creating new commitlog segment
>>>> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>>>>  INFO 21:30:40,944 read 0 from saved key cache
>>>>  INFO 21:30:40,949 read 0 from saved key cache
>>>>  INFO 21:30:40,950 read 0 from saved key cache
>>>>  INFO 21:30:40,952 read 0 from saved key cache
>>>>  INFO 21:30:40,953 read 0 from saved key cache
>>>>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>>>>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
>>>> LocationInfo of system
>>>>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>>>>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
>>>> HintsColumnFamily of system
>>>>  INFO 21:30:41,010 loading row cache for Migrations of system
>>>>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
>>>> Migrations of system
>>>>  INFO 21:30:41,014 loading row cache for Schema of system
>>>>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for
>>>> Schema of system
>>>>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>>>>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
>>>> IndexInfo of system
>>>>  INFO 21:30:41,121 Couldn't detect any schema definitions in local
>>>> storage.
>>>>  INFO 21:30:41,123 Found table data in data directories. Consider using
>>>> JMX to call orgapache.cassandra.service.StorageService.loadSchemaFromYaml().
>>>>  INFO 21:30:41,126 No commitlog files found; skipping replay
>>>>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
>>>> hints will be snapshotted.
>>>>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>>>>  INFO 21:30:41,224 Thrift API version: 19.4.0
>>>>  INFO 21:30:41,240 Loading persisted ring state
>>>>  INFO 21:30:41,251 Starting up server gossip
>>>>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=700)
>>>>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
>>>> bytes, 4 operations)
>>>>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes,
>>>> 4 operations)
>>>>  INFO 21:30:41,536 Completed flushing
>>>> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>>>>  WARN 21:30:41,622 Generated random token
>>>> 77213727368801109223786819704694530797. Random tokens will result in an
>>>> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>>>>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=848)
>>>>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
>>>> bytes, 1 operations)
>>>>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
>>>> operations)
>>>>  INFO 21:30:41,717 Completed flushing
>>>> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>>>>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
>>>> classpath
>>>>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160<http://127.00.1:9160>
>>>>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of
>>>> 15728640 bytes.
>>>>  INFO 21:30:41,850 Listening for thrift clients...
>>>>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=11605)
>>>>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
>>>> bytes, 1 operations)
>>>>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=11605)
>>>>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
>>>> bytes, 3 operations)
>>>>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
>>>> operations)
>>>>  INFO 21:31:20,532 Completed flushing
>>>> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>>>>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
>>>> operations)
>>>>  INFO 21:31:20,627 Completed flushing
>>>> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>>>>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=24059)
>>>>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
>>>> bytes, 1 operations)
>>>>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=24059)
>>>>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
>>>> operations)
>>>>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
>>>> bytes, 3 operations)
>>>>  INFO 21:31:26,651 Completed flushing
>>>> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>>>>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
>>>> operations)
>>>>  INFO 21:31:26,764 Completed flushing
>>>> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>>>>  INFO 21:31:26,767 read 0 from saved key cache
>>>>  INFO 21:31:26,770 read 0 from saved key cache
>>>>  INFO 21:31:26,770 Creating index
>>>> org.apache.cassandra.db.Table@7e7f8062.Test.test1
>>>> ERROR 21:31:26,808 Fatal exception in thread
>>>> Thread[MigrationStage:1,5,main]
>>>> java.lang.IndexOutOfBoundsException
>>>> at java.nio.Buffer.checkIndex(Buffer.java:520)
>>>> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>>>>  at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
>>>> at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>>>>  at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
>>>> at
>>>> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>>>>  at
>>>> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
>>>> at
>>>> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>>>>  at org.apache.cassandra.db.TableinitCf(Table.java:335)
>>>> at
>>>> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>>>>  at
>>>> org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
>>>> at
>>>> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>>>>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
>>>> at java.util.concurrent.FutureTask.run(FutureTask.java:138)
>>>>  at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>> at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>  at java.lang.Thread.run(Thread.java:680)
>>>> ERROR 21:31:26,809 Thrift error occurred during processing of message.
>>>> org.apache.thrift.protocol.TProtocolException: Required field 'why' was
>>>> not present! Struct: InvalidRequestException(why:null)
>>>>  at
>>>> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
>>>> at
>>>> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>>>>  at
>>>> org.apache.cassandra.thrift.Cassandra$system_add_column_family_resultwrite(Cassandra.java:23401)
>>>> at
>>>> org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>>>>  at
>>>> org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
>>>> at
>>>> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>>>>  at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>> at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>  at javalang.Thread.run(Thread.java:680)
>>>>
>>>>
>>>>
>>>
>>
>

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by André Fiedler <fi...@googlemail.com>.
Ups, sry... checked out the trunk, not branch... my fault :D


2010/11/16 André Fiedler <fi...@googlemail.com>

> Latest branch doesn´t start:
>
> ------------------------- Log ------------------------------
>
> Exception in thread "main" java.lang.NoClassDefFoundError:
> org/apache/cassandra/thrift/CassandraDaemon
> Caused by: java.lang.ClassNotFoundException:
> org.apache.cassandra.thrift.CassandraDaemon
> at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
>  at java.security.AccessController.doPrivileged(Native Method)
> at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
>  at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
> at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
>  at java.lang.ClassLoader.loadClass(ClassLoader.java:248)
>
>
>
> 2010/11/16 André Fiedler <fi...@googlemail.com>
>
> Thx! :o) so i will do
>>
>> 2010/11/16 Jake Luciani <ja...@gmail.com>
>>
>> This is a bug in beta3, if you checkout the cassandra-0.7 branch it should
>>> work for you.
>>>
>>>
>>> On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <
>>> fiedler.andre@googlemail.com> wrote:
>>>
>>>> I try to perform the following action after a clean startup. And get the
>>>> log below. How to fix this?
>>>>
>>>> ------------------------- Action ------------------------------
>>>>
>>>> create column family Test with comparator=LexicalUUIDType and
>>>> column_metadata=[
>>>>
>>>>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test1},
>>>>
>>>>     {column_name:test2, validation_class:UTF8Type, index_type:0,
>>>> index_name:test2},
>>>>
>>>>     {column_name:test3, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test4},
>>>>
>>>>     {column_name:test5, validation_class:BytesType, index_type:0,
>>>> index_name:test5},
>>>>
>>>>     {column_name:test6, validation_class:BytesType, index_type:0,
>>>> index_name:test6},
>>>>
>>>>     {column_name:test7, validation_class:LongType, index_type:0,
>>>> index_name:test7},
>>>>
>>>>     {column_name:test8, validation_class:BytesType, index_type:0,
>>>> index_name:test8},
>>>>
>>>>     {column_name:test9, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test10, validation_class:LongType},
>>>>
>>>>     {column_name:test11, validation_class:UTF8Type},
>>>>
>>>>     {column_name:test12, validation_class:LongType},
>>>>
>>>>     {column_name:test13, validation_class:LongType},
>>>>
>>>>     {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
>>>> index_name:test14}
>>>>
>>>> ]
>>>>
>>>>
>>>> ------------------------- Log ------------------------------
>>>>
>>>>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>>>>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>>>>  INFO 21:30:40,151 Loading settings from
>>>> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>>>>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
>>>> indexAccessMode is mmap
>>>>  INFO 21:30:40,822 Creating new commitlog segment
>>>> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>>>>  INFO 21:30:40,944 read 0 from saved key cache
>>>>  INFO 21:30:40,949 read 0 from saved key cache
>>>>  INFO 21:30:40,950 read 0 from saved key cache
>>>>  INFO 21:30:40,952 read 0 from saved key cache
>>>>  INFO 21:30:40,953 read 0 from saved key cache
>>>>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>>>>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
>>>> LocationInfo of system
>>>>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>>>>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
>>>> HintsColumnFamily of system
>>>>  INFO 21:30:41,010 loading row cache for Migrations of system
>>>>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
>>>> Migrations of system
>>>>  INFO 21:30:41,014 loading row cache for Schema of system
>>>>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for
>>>> Schema of system
>>>>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>>>>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
>>>> IndexInfo of system
>>>>  INFO 21:30:41,121 Couldn't detect any schema definitions in local
>>>> storage.
>>>>  INFO 21:30:41,123 Found table data in data directories. Consider using
>>>> JMX to call
>>>> org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
>>>>  INFO 21:30:41,126 No commitlog files found; skipping replay
>>>>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
>>>> hints will be snapshotted.
>>>>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>>>>  INFO 21:30:41,224 Thrift API version: 19.4.0
>>>>  INFO 21:30:41,240 Loading persisted ring state
>>>>  INFO 21:30:41,251 Starting up server gossip
>>>>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=700)
>>>>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
>>>> bytes, 4 operations)
>>>>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes,
>>>> 4 operations)
>>>>  INFO 21:30:41,536 Completed flushing
>>>> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>>>>  WARN 21:30:41,622 Generated random token
>>>> 77213727368801109223786819704694530797. Random tokens will result in an
>>>> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>>>>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=848)
>>>>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
>>>> bytes, 1 operations)
>>>>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
>>>> operations)
>>>>  INFO 21:30:41,717 Completed flushing
>>>> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>>>>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
>>>> classpath
>>>>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
>>>>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of
>>>> 15728640 bytes.
>>>>  INFO 21:30:41,850 Listening for thrift clients...
>>>>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=11605)
>>>>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
>>>> bytes, 1 operations)
>>>>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=11605)
>>>>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
>>>> bytes, 3 operations)
>>>>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
>>>> operations)
>>>>  INFO 21:31:20,532 Completed flushing
>>>> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>>>>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
>>>> operations)
>>>>  INFO 21:31:20,627 Completed flushing
>>>> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>>>>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=24059)
>>>>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
>>>> bytes, 1 operations)
>>>>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
>>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>>> position=24059)
>>>>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
>>>> operations)
>>>>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
>>>> bytes, 3 operations)
>>>>  INFO 21:31:26,651 Completed flushing
>>>> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>>>>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
>>>> operations)
>>>>  INFO 21:31:26,764 Completed flushing
>>>> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>>>>  INFO 21:31:26,767 read 0 from saved key cache
>>>>  INFO 21:31:26,770 read 0 from saved key cache
>>>>  INFO 21:31:26,770 Creating index
>>>> org.apache.cassandra.db.Table@7e7f8062.Test.test1
>>>> ERROR 21:31:26,808 Fatal exception in thread
>>>> Thread[MigrationStage:1,5,main]
>>>> java.lang.IndexOutOfBoundsException
>>>> at java.nio.Buffer.checkIndex(Buffer.java:520)
>>>> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>>>>  at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
>>>> at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>>>>  at
>>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
>>>> at
>>>> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>>>>  at
>>>> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
>>>> at
>>>> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>>>>  at
>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
>>>> at
>>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>>>>  at org.apache.cassandra.db.Table.initCf(Table.java:335)
>>>> at
>>>> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>>>>  at
>>>> org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
>>>> at
>>>> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>>>>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
>>>> at java.util.concurrent.FutureTask.run(FutureTask.java:138)
>>>>  at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>> at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>  at java.lang.Thread.run(Thread.java:680)
>>>> ERROR 21:31:26,809 Thrift error occurred during processing of message.
>>>> org.apache.thrift.protocol.TProtocolException: Required field 'why' was
>>>> not present! Struct: InvalidRequestException(why:null)
>>>>  at
>>>> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
>>>> at
>>>> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>>>>  at
>>>> org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
>>>> at
>>>> org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>>>>  at
>>>> org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
>>>> at
>>>> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>>>>  at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>>> at
>>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>>  at java.lang.Thread.run(Thread.java:680)
>>>>
>>>>
>>>>
>>>
>>
>

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by Aaron Morton <aa...@thelastpickle.com>.
did you do a clean and then build ? "ant clean" then "ant jar"

Aaron


On 17 Nov, 2010,at 10:10 AM, André Fiedler <fi...@googlemail.com> wrote:

Latest branch doesn´t start:

------------------------- Log ------------------------------

Exception in thread "main" java.lang.NoClassDefFoundError: org/apache/cassandra/thrift/CassandraDaemon
Caused by: java.lang.ClassNotFoundException: org.apache.cassandra.thrift.CassandraDaemon
	at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
	at java.security.AccessController.doPrivileged(Native Method)
	at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
	at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
	at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
	at java.lang.ClassLoader.loadClass(ClassLoader.java:248)



2010/11/16 André Fiedler <fi...@googlemail.com>
Thx! :o) so i will do

2010/11/16 Jake Luciani <ja...@gmail.com>


This is a bug in beta3, if you checkout the cassandra-0.7 branch it should work for you.



On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <fi...@googlemail.com> wrote:
I try to perform the following action after a clean startup. And get the log below. How to fix this?

------------------------- Action ------------------------------

create column family Test with comparator=LexicalUUIDType and column_metadata=[
    {column_name:test1, validation_class:LexicalUUIDType, index_type:0, index_name:test1},
    {column_name:test2, validation_class:UTF8Type, index_type:0, index_name:test2},
    {column_name:test3, validation_class:UTF8Type},
    {column_name:test4, validation_class:LexicalUUIDType, index_type:0, index_name:test4},
    {column_name:test5, validation_class:BytesType, index_type:0, index_name:test5},
    {column_name:test6, validation_class:BytesType, index_type:0, index_name:test6},
    {column_name:test7, validation_class:LongType, index_type:0, index_name:test7},
    {column_name:test8, validation_class:BytesType, index_type:0, index_name:test8},
    {column_name:test9, validation_class:UTF8Type},
    {column_name:test10, validation_class:LongType},
    {column_name:test11, validation_class:UTF8Type},
    {column_name:test12, validation_class:LongType},
    {column_name:test13, validation_class:LongType},
    {column_name:test14, validation_class:LexicalUUIDType, index_type:0, index_name:test14}
]

------------------------- Log ------------------------------

 INFO 21:30:40,004 Heap size: 1069416448/1069416448
 INFO 21:30:40,098 JNA not found. Native methods will be disabled.
 INFO 21:30:40,151 Loading settings from file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
 INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap, indexAccessMode is mmap
 INFO 21:30:40,822 Creating new commitlog segment /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
 INFO 21:30:40,944 read 0 from saved key cache
 INFO 21:30:40,949 read 0 from saved key cache
 INFO 21:30:40,950 read 0 from saved key cache
 INFO 21:30:40,952 read 0 from saved key cache
 INFO 21:30:40,953 read 0 from saved key cache
 INFO 21:30:41,007 loading row cache for LocationInfo of system
 INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for LocationInfo of system
 INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
 INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for HintsColumnFamily of system
 INFO 21:30:41,010 loading row cache for Migrations of system
 INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for Migrations of system
 INFO 21:30:41,014 loading row cache for Schema of system
 INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema of system
 INFO 21:30:41,015 loading row cache for IndexInfo of system
 INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for IndexInfo of system
 INFO 21:30:41,121 Couldn't detect any schema definitions in local storage.
 INFO 21:30:41,123 Found table data in data directories. Consider using JMX to call org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
 INFO 21:30:41,126 No commitlog files found; skipping replay
 INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old hints will be snapshotted.
 INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
 INFO 21:30:41,224 Thrift API version: 19.4.0
 INFO 21:30:41,240 Loading persisted ring state
 INFO 21:30:41,251 Starting up server gossip
 INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=700)
 INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227 bytes, 4 operations)
 INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4 operations)
 INFO 21:30:41,536 Completed flushing /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
 WARN 21:30:41,622 Generated random token 77213727368801109223786819704694530797. Random tokens will result in an unbalanced ring; see http://wiki.apache.org/cassandra/Operations
 INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=848)
 INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36 bytes, 1 operations)
 INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1 operations)
 INFO 21:30:41,717 Completed flushing /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
 INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the classpath
 INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
 INFO 21:30:41,828 Using TFramedTransport with a max frame size of 15728640 bytes.
 INFO 21:30:41,850 Listening for thrift clients...
 INFO 21:31:20,385 switching in a fresh Memtable for Migrations at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=11605)
 INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082 bytes, 1 operations)
 INFO 21:31:20,386 switching in a fresh Memtable for Schema at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=11605)
 INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184 bytes, 3 operations)
 INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1 operations)
 INFO 21:31:20,532 Completed flushing /var/lib/cassandra/data/system/Migrations-e-1-Data.db
 INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3 operations)
 INFO 21:31:20,627 Completed flushing /var/lib/cassandra/data/system/Schema-e-1-Data.db
 INFO 21:31:26,556 switching in a fresh Memtable for Migrations at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=24059)
 INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927 bytes, 1 operations)
 INFO 21:31:26,557 switching in a fresh Memtable for Schema at CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log', position=24059)
 INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1 operations)
 INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131 bytes, 3 operations)
 INFO 21:31:26,651 Completed flushing /var/lib/cassandra/data/system/Migrations-e-2-Data.db
 INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3 operations)
 INFO 21:31:26,764 Completed flushing /var/lib/cassandra/data/system/Schema-e-2-Data.db
 INFO 21:31:26,767 read 0 from saved key cache
 INFO 21:31:26,770 read 0 from saved key cache
 INFO 21:31:26,770 Creating index org.apache.cassandra.db.Table@7e7f8062.Test.test1
ERROR 21:31:26,808 Fatal exception in thread Thread[MigrationStage:1,5,main]
java.lang.IndexOutOfBoundsException
	at java.nio.Buffer.checkIndex(Buffer.java:520)
	at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
	at org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
	at java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
	at java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
	at java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
	at org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
	at org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
	at org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
	at org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
	at org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
	at org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
	at org.apache.cassandradb.Table.initCf(Table.java:335)
	at org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
	at org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
	at org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
	at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
	at java.util.concurrent.FutureTask.run(FutureTask.java:138)
	at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
	at java.lang.Thread.run(Thread.java:680)
ERROR 21:31:26,809 Thrift error occurred during processing of message.
org.apache.thrift.protocol.TProtocolException: Required field 'why' was not present! Struct: InvalidRequestException(why:null)
	at org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
	at org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
	at org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
	at org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
	at org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
	at org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
	at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
	at java.lang.Thread.run(Thread.java:680)






Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by André Fiedler <fi...@googlemail.com>.
Latest branch doesn´t start:

------------------------- Log ------------------------------

Exception in thread "main" java.lang.NoClassDefFoundError:
org/apache/cassandra/thrift/CassandraDaemon
Caused by: java.lang.ClassNotFoundException:
org.apache.cassandra.thrift.CassandraDaemon
at java.net.URLClassLoader$1.run(URLClassLoader.java:202)
 at java.security.AccessController.doPrivileged(Native Method)
at java.net.URLClassLoader.findClass(URLClassLoader.java:190)
 at java.lang.ClassLoader.loadClass(ClassLoader.java:307)
at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:301)
 at java.lang.ClassLoader.loadClass(ClassLoader.java:248)



2010/11/16 André Fiedler <fi...@googlemail.com>

> Thx! :o) so i will do
>
> 2010/11/16 Jake Luciani <ja...@gmail.com>
>
> This is a bug in beta3, if you checkout the cassandra-0.7 branch it should
>> work for you.
>>
>>
>> On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <
>> fiedler.andre@googlemail.com> wrote:
>>
>>> I try to perform the following action after a clean startup. And get the
>>> log below. How to fix this?
>>>
>>> ------------------------- Action ------------------------------
>>>
>>> create column family Test with comparator=LexicalUUIDType and
>>> column_metadata=[
>>>
>>>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
>>> index_name:test1},
>>>
>>>     {column_name:test2, validation_class:UTF8Type, index_type:0,
>>> index_name:test2},
>>>
>>>     {column_name:test3, validation_class:UTF8Type},
>>>
>>>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
>>> index_name:test4},
>>>
>>>     {column_name:test5, validation_class:BytesType, index_type:0,
>>> index_name:test5},
>>>
>>>     {column_name:test6, validation_class:BytesType, index_type:0,
>>> index_name:test6},
>>>
>>>     {column_name:test7, validation_class:LongType, index_type:0,
>>> index_name:test7},
>>>
>>>     {column_name:test8, validation_class:BytesType, index_type:0,
>>> index_name:test8},
>>>
>>>     {column_name:test9, validation_class:UTF8Type},
>>>
>>>     {column_name:test10, validation_class:LongType},
>>>
>>>     {column_name:test11, validation_class:UTF8Type},
>>>
>>>     {column_name:test12, validation_class:LongType},
>>>
>>>     {column_name:test13, validation_class:LongType},
>>>
>>>     {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
>>> index_name:test14}
>>>
>>> ]
>>>
>>>
>>> ------------------------- Log ------------------------------
>>>
>>>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>>>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>>>  INFO 21:30:40,151 Loading settings from
>>> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>>>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
>>> indexAccessMode is mmap
>>>  INFO 21:30:40,822 Creating new commitlog segment
>>> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>>>  INFO 21:30:40,944 read 0 from saved key cache
>>>  INFO 21:30:40,949 read 0 from saved key cache
>>>  INFO 21:30:40,950 read 0 from saved key cache
>>>  INFO 21:30:40,952 read 0 from saved key cache
>>>  INFO 21:30:40,953 read 0 from saved key cache
>>>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>>>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
>>> LocationInfo of system
>>>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>>>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
>>> HintsColumnFamily of system
>>>  INFO 21:30:41,010 loading row cache for Migrations of system
>>>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
>>> Migrations of system
>>>  INFO 21:30:41,014 loading row cache for Schema of system
>>>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema
>>> of system
>>>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>>>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
>>> IndexInfo of system
>>>  INFO 21:30:41,121 Couldn't detect any schema definitions in local
>>> storage.
>>>  INFO 21:30:41,123 Found table data in data directories. Consider using
>>> JMX to call
>>> org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
>>>  INFO 21:30:41,126 No commitlog files found; skipping replay
>>>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
>>> hints will be snapshotted.
>>>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>>>  INFO 21:30:41,224 Thrift API version: 19.4.0
>>>  INFO 21:30:41,240 Loading persisted ring state
>>>  INFO 21:30:41,251 Starting up server gossip
>>>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=700)
>>>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
>>> bytes, 4 operations)
>>>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4
>>> operations)
>>>  INFO 21:30:41,536 Completed flushing
>>> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>>>  WARN 21:30:41,622 Generated random token
>>> 77213727368801109223786819704694530797. Random tokens will result in an
>>> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>>>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=848)
>>>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
>>> bytes, 1 operations)
>>>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
>>> operations)
>>>  INFO 21:30:41,717 Completed flushing
>>> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>>>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
>>> classpath
>>>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
>>>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of
>>> 15728640 bytes.
>>>  INFO 21:30:41,850 Listening for thrift clients...
>>>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=11605)
>>>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
>>> bytes, 1 operations)
>>>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=11605)
>>>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
>>> bytes, 3 operations)
>>>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
>>> operations)
>>>  INFO 21:31:20,532 Completed flushing
>>> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>>>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
>>> operations)
>>>  INFO 21:31:20,627 Completed flushing
>>> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>>>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=24059)
>>>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
>>> bytes, 1 operations)
>>>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
>>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>>> position=24059)
>>>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
>>> operations)
>>>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
>>> bytes, 3 operations)
>>>  INFO 21:31:26,651 Completed flushing
>>> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>>>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
>>> operations)
>>>  INFO 21:31:26,764 Completed flushing
>>> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>>>  INFO 21:31:26,767 read 0 from saved key cache
>>>  INFO 21:31:26,770 read 0 from saved key cache
>>>  INFO 21:31:26,770 Creating index
>>> org.apache.cassandra.db.Table@7e7f8062.Test.test1
>>> ERROR 21:31:26,808 Fatal exception in thread
>>> Thread[MigrationStage:1,5,main]
>>> java.lang.IndexOutOfBoundsException
>>> at java.nio.Buffer.checkIndex(Buffer.java:520)
>>> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>>>  at
>>> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
>>> at
>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>>>  at
>>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
>>> at
>>> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>>>  at
>>> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
>>> at
>>> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>>>  at
>>> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
>>> at
>>> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>>>  at
>>> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
>>> at
>>> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>>>  at
>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
>>> at
>>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>>>  at org.apache.cassandra.db.Table.initCf(Table.java:335)
>>> at
>>> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>>>  at
>>> org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
>>> at
>>> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>>>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
>>> at java.util.concurrent.FutureTask.run(FutureTask.java:138)
>>>  at
>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>> at
>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>  at java.lang.Thread.run(Thread.java:680)
>>> ERROR 21:31:26,809 Thrift error occurred during processing of message.
>>> org.apache.thrift.protocol.TProtocolException: Required field 'why' was
>>> not present! Struct: InvalidRequestException(why:null)
>>>  at
>>> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
>>> at
>>> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>>>  at
>>> org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
>>> at
>>> org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>>>  at
>>> org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
>>> at
>>> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>>>  at
>>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>>> at
>>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>>  at java.lang.Thread.run(Thread.java:680)
>>>
>>>
>>>
>>
>

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by André Fiedler <fi...@googlemail.com>.
Thx! :o) so i will do

2010/11/16 Jake Luciani <ja...@gmail.com>

> This is a bug in beta3, if you checkout the cassandra-0.7 branch it should
> work for you.
>
>
> On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <
> fiedler.andre@googlemail.com> wrote:
>
>> I try to perform the following action after a clean startup. And get the
>> log below. How to fix this?
>>
>> ------------------------- Action ------------------------------
>>
>> create column family Test with comparator=LexicalUUIDType and
>> column_metadata=[
>>
>>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
>> index_name:test1},
>>
>>     {column_name:test2, validation_class:UTF8Type, index_type:0,
>> index_name:test2},
>>
>>     {column_name:test3, validation_class:UTF8Type},
>>
>>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
>> index_name:test4},
>>
>>     {column_name:test5, validation_class:BytesType, index_type:0,
>> index_name:test5},
>>
>>     {column_name:test6, validation_class:BytesType, index_type:0,
>> index_name:test6},
>>
>>     {column_name:test7, validation_class:LongType, index_type:0,
>> index_name:test7},
>>
>>     {column_name:test8, validation_class:BytesType, index_type:0,
>> index_name:test8},
>>
>>     {column_name:test9, validation_class:UTF8Type},
>>
>>     {column_name:test10, validation_class:LongType},
>>
>>     {column_name:test11, validation_class:UTF8Type},
>>
>>     {column_name:test12, validation_class:LongType},
>>
>>     {column_name:test13, validation_class:LongType},
>>
>>     {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
>> index_name:test14}
>>
>> ]
>>
>>
>> ------------------------- Log ------------------------------
>>
>>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>>  INFO 21:30:40,151 Loading settings from
>> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
>> indexAccessMode is mmap
>>  INFO 21:30:40,822 Creating new commitlog segment
>> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>>  INFO 21:30:40,944 read 0 from saved key cache
>>  INFO 21:30:40,949 read 0 from saved key cache
>>  INFO 21:30:40,950 read 0 from saved key cache
>>  INFO 21:30:40,952 read 0 from saved key cache
>>  INFO 21:30:40,953 read 0 from saved key cache
>>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
>> LocationInfo of system
>>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
>> HintsColumnFamily of system
>>  INFO 21:30:41,010 loading row cache for Migrations of system
>>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
>> Migrations of system
>>  INFO 21:30:41,014 loading row cache for Schema of system
>>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema
>> of system
>>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
>> IndexInfo of system
>>  INFO 21:30:41,121 Couldn't detect any schema definitions in local
>> storage.
>>  INFO 21:30:41,123 Found table data in data directories. Consider using
>> JMX to call
>> org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
>>  INFO 21:30:41,126 No commitlog files found; skipping replay
>>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
>> hints will be snapshotted.
>>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>>  INFO 21:30:41,224 Thrift API version: 19.4.0
>>  INFO 21:30:41,240 Loading persisted ring state
>>  INFO 21:30:41,251 Starting up server gossip
>>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=700)
>>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
>> bytes, 4 operations)
>>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4
>> operations)
>>  INFO 21:30:41,536 Completed flushing
>> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>>  WARN 21:30:41,622 Generated random token
>> 77213727368801109223786819704694530797. Random tokens will result in an
>> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=848)
>>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
>> bytes, 1 operations)
>>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
>> operations)
>>  INFO 21:30:41,717 Completed flushing
>> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
>> classpath
>>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
>>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of
>> 15728640 bytes.
>>  INFO 21:30:41,850 Listening for thrift clients...
>>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=11605)
>>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
>> bytes, 1 operations)
>>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=11605)
>>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
>> bytes, 3 operations)
>>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
>> operations)
>>  INFO 21:31:20,532 Completed flushing
>> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
>> operations)
>>  INFO 21:31:20,627 Completed flushing
>> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=24059)
>>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
>> bytes, 1 operations)
>>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
>> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
>> position=24059)
>>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
>> operations)
>>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
>> bytes, 3 operations)
>>  INFO 21:31:26,651 Completed flushing
>> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
>> operations)
>>  INFO 21:31:26,764 Completed flushing
>> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>>  INFO 21:31:26,767 read 0 from saved key cache
>>  INFO 21:31:26,770 read 0 from saved key cache
>>  INFO 21:31:26,770 Creating index
>> org.apache.cassandra.db.Table@7e7f8062.Test.test1
>> ERROR 21:31:26,808 Fatal exception in thread
>> Thread[MigrationStage:1,5,main]
>> java.lang.IndexOutOfBoundsException
>> at java.nio.Buffer.checkIndex(Buffer.java:520)
>> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>>  at
>> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
>> at
>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>>  at
>> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
>> at
>> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>>  at
>> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
>> at
>> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>>  at
>> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
>> at
>> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>>  at
>> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
>> at
>> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>>  at
>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
>> at
>> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>>  at org.apache.cassandra.db.Table.initCf(Table.java:335)
>> at
>> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>>  at org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
>> at
>> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
>> at java.util.concurrent.FutureTask.run(FutureTask.java:138)
>>  at
>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>> at
>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>  at java.lang.Thread.run(Thread.java:680)
>> ERROR 21:31:26,809 Thrift error occurred during processing of message.
>> org.apache.thrift.protocol.TProtocolException: Required field 'why' was
>> not present! Struct: InvalidRequestException(why:null)
>>  at
>> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
>> at
>> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>>  at
>> org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
>> at
>> org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>>  at
>> org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
>> at
>> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>>  at
>> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
>> at
>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>>  at java.lang.Thread.run(Thread.java:680)
>>
>>
>>
>

Re: Cassandra 0.7-beta3 - IndexOutOfBoundsException when create column family

Posted by Jake Luciani <ja...@gmail.com>.
This is a bug in beta3, if you checkout the cassandra-0.7 branch it should
work for you.

On Tue, Nov 16, 2010 at 3:38 PM, André Fiedler <fiedler.andre@googlemail.com
> wrote:

> I try to perform the following action after a clean startup. And get the
> log below. How to fix this?
>
> ------------------------- Action ------------------------------
>
> create column family Test with comparator=LexicalUUIDType and
> column_metadata=[
>
>     {column_name:test1, validation_class:LexicalUUIDType, index_type:0,
> index_name:test1},
>
>     {column_name:test2, validation_class:UTF8Type, index_type:0,
> index_name:test2},
>
>     {column_name:test3, validation_class:UTF8Type},
>
>     {column_name:test4, validation_class:LexicalUUIDType, index_type:0,
> index_name:test4},
>
>     {column_name:test5, validation_class:BytesType, index_type:0,
> index_name:test5},
>
>     {column_name:test6, validation_class:BytesType, index_type:0,
> index_name:test6},
>
>     {column_name:test7, validation_class:LongType, index_type:0,
> index_name:test7},
>
>     {column_name:test8, validation_class:BytesType, index_type:0,
> index_name:test8},
>
>     {column_name:test9, validation_class:UTF8Type},
>
>     {column_name:test10, validation_class:LongType},
>
>     {column_name:test11, validation_class:UTF8Type},
>
>     {column_name:test12, validation_class:LongType},
>
>     {column_name:test13, validation_class:LongType},
>
>     {column_name:test14, validation_class:LexicalUUIDType, index_type:0,
> index_name:test14}
>
> ]
>
>
> ------------------------- Log ------------------------------
>
>  INFO 21:30:40,004 Heap size: 1069416448/1069416448
>  INFO 21:30:40,098 JNA not found. Native methods will be disabled.
>  INFO 21:30:40,151 Loading settings from
> file:/Applications/apache-cassandra-0.7.0-beta3/conf/cassandra.yaml
>  INFO 21:30:40,569 DiskAccessMode 'auto' determined to be mmap,
> indexAccessMode is mmap
>  INFO 21:30:40,822 Creating new commitlog segment
> /var/lib/cassandra/commitlog/CommitLog-1289939440822.log
>  INFO 21:30:40,944 read 0 from saved key cache
>  INFO 21:30:40,949 read 0 from saved key cache
>  INFO 21:30:40,950 read 0 from saved key cache
>  INFO 21:30:40,952 read 0 from saved key cache
>  INFO 21:30:40,953 read 0 from saved key cache
>  INFO 21:30:41,007 loading row cache for LocationInfo of system
>  INFO 21:30:41,007 completed loading (1 ms; 0 keys)  row cache for
> LocationInfo of system
>  INFO 21:30:41,008 loading row cache for HintsColumnFamily of system
>  INFO 21:30:41,009 completed loading (1 ms; 0 keys)  row cache for
> HintsColumnFamily of system
>  INFO 21:30:41,010 loading row cache for Migrations of system
>  INFO 21:30:41,010 completed loading (1 ms; 0 keys)  row cache for
> Migrations of system
>  INFO 21:30:41,014 loading row cache for Schema of system
>  INFO 21:30:41,014 completed loading (0 ms; 0 keys)  row cache for Schema
> of system
>  INFO 21:30:41,015 loading row cache for IndexInfo of system
>  INFO 21:30:41,016 completed loading (0 ms; 0 keys)  row cache for
> IndexInfo of system
>  INFO 21:30:41,121 Couldn't detect any schema definitions in local storage.
>  INFO 21:30:41,123 Found table data in data directories. Consider using JMX
> to call org.apache.cassandra.service.StorageService.loadSchemaFromYaml().
>  INFO 21:30:41,126 No commitlog files found; skipping replay
>  INFO 21:30:41,165 Upgrading to 0.7. Purging hints if there are any. Old
> hints will be snapshotted.
>  INFO 21:30:41,223 Cassandra version: 0.7.0-beta3
>  INFO 21:30:41,224 Thrift API version: 19.4.0
>  INFO 21:30:41,240 Loading persisted ring state
>  INFO 21:30:41,251 Starting up server gossip
>  INFO 21:30:41,268 switching in a fresh Memtable for LocationInfo at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=700)
>  INFO 21:30:41,270 Enqueuing flush of Memtable-LocationInfo@1085278557(227
> bytes, 4 operations)
>  INFO 21:30:41,272 Writing Memtable-LocationInfo@1085278557(227 bytes, 4
> operations)
>  INFO 21:30:41,536 Completed flushing
> /var/lib/cassandra/data/system/LocationInfo-e-1-Data.db
>  WARN 21:30:41,622 Generated random token
> 77213727368801109223786819704694530797. Random tokens will result in an
> unbalanced ring; see http://wiki.apache.org/cassandra/Operations
>  INFO 21:30:41,623 switching in a fresh Memtable for LocationInfo at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=848)
>  INFO 21:30:41,623 Enqueuing flush of Memtable-LocationInfo@767012386(36
> bytes, 1 operations)
>  INFO 21:30:41,623 Writing Memtable-LocationInfo@767012386(36 bytes, 1
> operations)
>  INFO 21:30:41,717 Completed flushing
> /var/lib/cassandra/data/system/LocationInfo-e-2-Data.db
>  INFO 21:30:41,723 Will not load MX4J, mx4j-tools.jar is not in the
> classpath
>  INFO 21:30:41,823 Binding thrift service to localhost/127.0.0.1:9160
>  INFO 21:30:41,828 Using TFramedTransport with a max frame size of 15728640
> bytes.
>  INFO 21:30:41,850 Listening for thrift clients...
>  INFO 21:31:20,385 switching in a fresh Memtable for Migrations at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=11605)
>  INFO 21:31:20,386 Enqueuing flush of Memtable-Migrations@1217256339(6082
> bytes, 1 operations)
>  INFO 21:31:20,386 switching in a fresh Memtable for Schema at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=11605)
>  INFO 21:31:20,387 Enqueuing flush of Memtable-Schema@1498068251(2184
> bytes, 3 operations)
>  INFO 21:31:20,390 Writing Memtable-Migrations@1217256339(6082 bytes, 1
> operations)
>  INFO 21:31:20,532 Completed flushing
> /var/lib/cassandra/data/system/Migrations-e-1-Data.db
>  INFO 21:31:20,533 Writing Memtable-Schema@1498068251(2184 bytes, 3
> operations)
>  INFO 21:31:20,627 Completed flushing
> /var/lib/cassandra/data/system/Schema-e-1-Data.db
>  INFO 21:31:26,556 switching in a fresh Memtable for Migrations at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=24059)
>  INFO 21:31:26,556 Enqueuing flush of Memtable-Migrations@1808117550(7927
> bytes, 1 operations)
>  INFO 21:31:26,557 switching in a fresh Memtable for Schema at
> CommitLogContext(file='/var/lib/cassandra/commitlog/CommitLog-1289939440822.log',
> position=24059)
>  INFO 21:31:26,557 Writing Memtable-Migrations@1808117550(7927 bytes, 1
> operations)
>  INFO 21:31:26,557 Enqueuing flush of Memtable-Schema@2138057800(3131
> bytes, 3 operations)
>  INFO 21:31:26,651 Completed flushing
> /var/lib/cassandra/data/system/Migrations-e-2-Data.db
>  INFO 21:31:26,652 Writing Memtable-Schema@2138057800(3131 bytes, 3
> operations)
>  INFO 21:31:26,764 Completed flushing
> /var/lib/cassandra/data/system/Schema-e-2-Data.db
>  INFO 21:31:26,767 read 0 from saved key cache
>  INFO 21:31:26,770 read 0 from saved key cache
>  INFO 21:31:26,770 Creating index
> org.apache.cassandra.db.Table@7e7f8062.Test.test1
> ERROR 21:31:26,808 Fatal exception in thread
> Thread[MigrationStage:1,5,main]
> java.lang.IndexOutOfBoundsException
> at java.nio.Buffer.checkIndex(Buffer.java:520)
> at java.nio.HeapByteBuffer.getLong(HeapByteBuffer.java:391)
>  at
> org.apache.cassandra.db.marshal.LexicalUUIDType.getUUID(LexicalUUIDType.java:37)
> at
> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:51)
>  at
> org.apache.cassandra.db.marshal.LexicalUUIDType.compare(LexicalUUIDType.java:29)
> at
> java.util.concurrent.ConcurrentSkipListMap$ComparableUsingComparator.compareTo(ConcurrentSkipListMap.java:606)
>  at
> java.util.concurrent.ConcurrentSkipListMap.doGet(ConcurrentSkipListMap.java:797)
> at
> java.util.concurrent.ConcurrentSkipListMap.get(ConcurrentSkipListMap.java:1640)
>  at
> org.apache.cassandra.db.ColumnFamilyStore.getIndexedColumnFamilyStore(ColumnFamilyStore.java:1777)
> at
> org.apache.cassandra.db.ColumnFamilyStore.buildSecondaryIndexes(ColumnFamilyStore.java:351)
>  at
> org.apache.cassandra.db.ColumnFamilyStore.addIndex(ColumnFamilyStore.java:336)
> at
> org.apache.cassandra.db.ColumnFamilyStore.<init>(ColumnFamilyStore.java:256)
>  at
> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:443)
> at
> org.apache.cassandra.db.ColumnFamilyStore.createColumnFamilyStore(ColumnFamilyStore.java:431)
>  at org.apache.cassandra.db.Table.initCf(Table.java:335)
> at
> org.apache.cassandra.db.migration.AddColumnFamily.applyModels(AddColumnFamily.java:89)
>  at org.apache.cassandra.db.migration.Migration.apply(Migration.java:158)
> at
> org.apache.cassandra.thrift.CassandraServer$2.call(CassandraServer.java:672)
>  at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
> at java.util.concurrent.FutureTask.run(FutureTask.java:138)
>  at
> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
> at
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>  at java.lang.Thread.run(Thread.java:680)
> ERROR 21:31:26,809 Thrift error occurred during processing of message.
> org.apache.thrift.protocol.TProtocolException: Required field 'why' was not
> present! Struct: InvalidRequestException(why:null)
>  at
> org.apache.cassandra.thrift.InvalidRequestException.validate(InvalidRequestException.java:340)
> at
> org.apache.cassandra.thrift.InvalidRequestException.write(InvalidRequestException.java:309)
>  at
> org.apache.cassandra.thrift.Cassandra$system_add_column_family_result.write(Cassandra.java:23401)
> at
> org.apache.cassandra.thrift.Cassandra$Processor$system_add_column_family.process(Cassandra.java:3415)
>  at
> org.apache.cassandra.thrift.Cassandra$Processor.process(Cassandra.java:2555)
> at
> org.apache.cassandra.thrift.CustomTThreadPoolServer$WorkerProcess.run(CustomTThreadPoolServer.java:167)
>  at
> java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
> at
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
>  at java.lang.Thread.run(Thread.java:680)
>
>
>