Advertisement
Guest User

cassandra.yaml

a guest
Oct 31st, 2013
162
0
Never
Not a member of Pastebin yet? Sign Up, it unlocks many cool features!
YAML 31.51 KB | None | 0 0
  1. # Cassandra storage config YAML
  2.  
  3. # NOTE:
  4. #   See http://wiki.apache.org/cassandra/StorageConfiguration for
  5. #   full explanations of configuration directives
  6. # /NOTE
  7.  
  8. # The name of the cluster. This is mainly used to prevent machines in
  9. # one logical cluster from joining another.
  10. cluster_name: 'Cluster'
  11.  
  12. # This defines the number of tokens randomly assigned to this node on the ring
  13. # The more tokens, relative to other nodes, the larger the proportion of data
  14. # that this node will store. You probably want all nodes to have the same number
  15. # of tokens assuming they have equal hardware capability.
  16. #
  17. # If you leave this unspecified, Cassandra will use the default of 1 token for legacy compatibility,
  18. # and will use the initial_token as described below.
  19. #
  20. # Specifying initial_token will override this setting.
  21. #
  22. # If you already have a cluster with 1 token per node, and wish to migrate to
  23. # multiple tokens per node, see http://wiki.apache.org/cassandra/Operations
  24. # num_tokens: 256
  25.  
  26. # If you haven't specified num_tokens, or have set it to the default of 1 then
  27. # you should always specify InitialToken when setting up a production
  28. # cluster for the first time, and often when adding capacity later.
  29. # The principle is that each node should be given an equal slice of
  30. # the token ring; see http://wiki.apache.org/cassandra/Operations
  31. # for more details.
  32. #
  33. # If blank, Cassandra will request a token bisecting the range of
  34. # the heaviest-loaded existing node.  If there is no load information
  35. # available, such as is the case with a new cluster, it will pick
  36. # a random token, which will lead to hot spots.
  37. initial_token: 0
  38.  
  39. # See http://wiki.apache.org/cassandra/HintedHandoff
  40. hinted_handoff_enabled: true
  41. # this defines the maximum amount of time a dead host will have hints
  42. # generated.  After it has been dead this long, new hints for it will not be
  43. # created until it has been seen alive and gone down again.
  44. max_hint_window_in_ms: 10800000 # 3 hours
  45. # Maximum throttle in KBs per second, per delivery thread.  This will be
  46. # reduced proportionally to the number of nodes in the cluster.  (If there
  47. # are two nodes in the cluster, each delivery thread will use the maximum
  48. # rate; if there are three, each will throttle to half of the maximum,
  49. # since we expect two nodes to be delivering hints simultaneously.)
  50. hinted_handoff_throttle_in_kb: 1024
  51. # Number of threads with which to deliver hints;
  52. # Consider increasing this number when you have multi-dc deployments, since
  53. # cross-dc handoff tends to be slower
  54. max_hints_delivery_threads: 2
  55.  
  56. # The following setting populates the page cache on memtable flush and compaction
  57. # WARNING: Enable this setting only when the whole node's data fits in memory.
  58. # Defaults to: false
  59. # populate_io_cache_on_flush: false
  60.  
  61. # Authentication backend, implementing IAuthenticator; used to identify users
  62. # Out of the box, Cassandra provides org.apache.cassandra.auth.{AllowAllAuthenticator,
  63. # PasswordAuthenticator}.
  64. #
  65. # - AllowAllAuthenticator performs no checks - set it to disable authentication.
  66. # - PasswordAuthenticator relies on username/password pairs to authenticate
  67. #   users. It keeps usernames and hashed passwords in system_auth.credentials table.
  68. #   Please increase system_auth keyspace replication factor if you use this authenticator.
  69. authenticator: AllowAllAuthenticator
  70.  
  71. # Authorization backend, implementing IAuthorizer; used to limit access/provide permissions
  72. # Out of the box, Cassandra provides org.apache.cassandra.auth.{AllowAllAuthorizer,
  73. # CassandraAuthorizer}.
  74. #
  75. # - AllowAllAuthorizer allows any action to any user - set it to disable authorization.
  76. # - CassandraAuthorizer stores permissions in system_auth.permissions table. Please
  77. #   increase system_auth keyspace replication factor if you use this authorizer.
  78. authorizer: AllowAllAuthorizer
  79.  
  80. # Validity period for permissions cache (fetching permissions can be an
  81. # expensive operation depending on the authorizer, CassandraAuthorizer is
  82. # one example). Defaults to 2000, set to 0 to disable.
  83. # Will be disabled automatically for AllowAllAuthorizer.
  84. permissions_validity_in_ms: 2000
  85.  
  86. # The partitioner is responsible for distributing rows (by key) across
  87. # nodes in the cluster.  Any IPartitioner may be used, including your
  88. # own as long as it is on the classpath.  Out of the box, Cassandra
  89. # provides org.apache.cassandra.dht.{Murmur3Partitioner, RandomPartitioner
  90. # ByteOrderedPartitioner, OrderPreservingPartitioner (deprecated)}.
  91. #
  92. # - RandomPartitioner distributes rows across the cluster evenly by md5.
  93. #   This is the default prior to 1.2 and is retained for compatibility.
  94. # - Murmur3Partitioner is similar to RandomPartioner but uses Murmur3_128
  95. #   Hash Function instead of md5.  When in doubt, this is the best option.
  96. # - ByteOrderedPartitioner orders rows lexically by key bytes.  BOP allows
  97. #   scanning rows in key order, but the ordering can generate hot spots
  98. #   for sequential insertion workloads.
  99. # - OrderPreservingPartitioner is an obsolete form of BOP, that stores
  100. # - keys in a less-efficient format and only works with keys that are
  101. #   UTF8-encoded Strings.
  102. # - CollatingOPP collates according to EN,US rules rather than lexical byte
  103. #   ordering.  Use this as an example if you need custom collation.
  104. #
  105. # See http://wiki.apache.org/cassandra/Operations for more on
  106. # partitioners and token selection.
  107. partitioner: org.apache.cassandra.dht.RandomPartitioner
  108.  
  109. # Directories where Cassandra should store data on disk.  Cassandra
  110. # will spread data evenly across them, subject to the granularity of
  111. # the configured compaction strategy.
  112. data_file_directories:
  113.    - /opt/others/cassandra/data
  114.  
  115. # commit log
  116. commitlog_directory: /opt/others/cassandra/commitlog
  117.  
  118. # policy for data disk failures:
  119. # stop: shut down gossip and Thrift, leaving the node effectively dead, but
  120. #       can still be inspected via JMX.
  121. # best_effort: stop using the failed disk and respond to requests based on
  122. #              remaining available sstables.  This means you WILL see obsolete
  123. #              data at CL.ONE!
  124. # ignore: ignore fatal errors and let requests fail, as in pre-1.2 Cassandra
  125. disk_failure_policy: stop
  126.  
  127. # Maximum size of the key cache in memory.
  128. #
  129. # Each key cache hit saves 1 seek and each row cache hit saves 2 seeks at the
  130. # minimum, sometimes more. The key cache is fairly tiny for the amount of
  131. # time it saves, so it's worthwhile to use it at large numbers.
  132. # The row cache saves even more time, but must contain the entire row,
  133. # so it is extremely space-intensive. It's best to only use the
  134. # row cache if you have hot rows or static rows.
  135. #
  136. # NOTE: if you reduce the size, you may not get you hottest keys loaded on startup.
  137. #
  138. # Default value is empty to make it "auto" (min(5% of Heap (in MB), 100MB)). Set to 0 to disable key cache.
  139. key_cache_size_in_mb:
  140. # Duration in seconds after which Cassandra should
  141. # save the key cache. Caches are saved to saved_caches_directory as
  142. # specified in this configuration file.
  143. #
  144. # Saved caches greatly improve cold-start speeds, and is relatively cheap in
  145. # terms of I/O for the key cache. Row cache saving is much more expensive and
  146. # has limited use.
  147. #
  148. # Default is 14400 or 4 hours.
  149. key_cache_save_period: 14400
  150.  
  151. # Number of keys from the key cache to save
  152. # Disabled by default, meaning all keys are going to be saved
  153. # key_cache_keys_to_save: 100
  154.  
  155. # Maximum size of the row cache in memory.
  156. # NOTE: if you reduce the size, you may not get you hottest keys loaded on startup.
  157. #
  158. # Default value is 0, to disable row caching.
  159. row_cache_size_in_mb: 0
  160.  
  161. # Duration in seconds after which Cassandra should
  162. # safe the row cache. Caches are saved to saved_caches_directory as specified
  163. # in this configuration file.
  164. #
  165. # Saved caches greatly improve cold-start speeds, and is relatively cheap in
  166. # terms of I/O for the key cache. Row cache saving is much more expensive and
  167. # has limited use.
  168. #
  169. # Default is 0 to disable saving the row cache.
  170. row_cache_save_period: 0
  171.  
  172. # Number of keys from the row cache to save
  173. # Disabled by default, meaning all keys are going to be saved
  174. # row_cache_keys_to_save: 100
  175.  
  176. # The provider for the row cache to use.
  177. #
  178. # Supported values are: ConcurrentLinkedHashCacheProvider, SerializingCacheProvider
  179. #
  180. # SerializingCacheProvider serialises the contents of the row and stores
  181. # it in native memory, i.e., off the JVM Heap. Serialized rows take
  182. # significantly less memory than "live" rows in the JVM, so you can cache
  183. # more rows in a given memory footprint.  And storing the cache off-heap
  184. # means you can use smaller heap sizes, reducing the impact of GC pauses.
  185. # Note however that when a row is requested from the row cache, it must be
  186. # deserialized into the heap for use.
  187. #
  188. # It is also valid to specify the fully-qualified class name to a class
  189. # that implements org.apache.cassandra.cache.IRowCacheProvider.
  190. #
  191. # Defaults to SerializingCacheProvider
  192. row_cache_provider: SerializingCacheProvider
  193.  
  194. # saved caches
  195. saved_caches_directory: /opt/others/cassandra/saved_caches
  196.  
  197. # commitlog_sync may be either "periodic" or "batch."
  198. # When in batch mode, Cassandra won't ack writes until the commit log
  199. # has been fsynced to disk.  It will wait up to
  200. # commitlog_sync_batch_window_in_ms milliseconds for other writes, before
  201. # performing the sync.
  202. #
  203. # commitlog_sync: batch
  204. # commitlog_sync_batch_window_in_ms: 50
  205. #
  206. # the other option is "periodic" where writes may be acked immediately
  207. # and the CommitLog is simply synced every commitlog_sync_period_in_ms
  208. # milliseconds.
  209. commitlog_sync: periodic
  210. commitlog_sync_period_in_ms: 10000
  211.  
  212. # The size of the individual commitlog file segments.  A commitlog
  213. # segment may be archived, deleted, or recycled once all the data
  214. # in it (potentially from each columnfamily in the system) has been
  215. # flushed to sstables.  
  216. #
  217. # The default size is 32, which is almost always fine, but if you are
  218. # archiving commitlog segments (see commitlog_archiving.properties),
  219. # then you probably want a finer granularity of archiving; 8 or 16 MB
  220. # is reasonable.
  221. commitlog_segment_size_in_mb: 32
  222.  
  223. # any class that implements the SeedProvider interface and has a
  224. # constructor that takes a Map<String, String> of parameters will do.
  225. seed_provider:
  226.    # Addresses of hosts that are deemed contact points.
  227.     # Cassandra nodes use this list of hosts to find each other and learn
  228.     # the topology of the ring.  You must change this if you are running
  229.     # multiple nodes!
  230.     - class_name: org.apache.cassandra.locator.SimpleSeedProvider
  231.       parameters:
  232.          # seeds is actually a comma-delimited list of addresses.
  233.           # Ex: "<ip1>,<ip2>,<ip3>"
  234.           - seeds: "192.168.135.29,192.168.135.50,192.168.135.74,172.16.13.78,172.16.14.205,172.16.14.153,192.168.135.79,192.168.135.41,192.168.135.27"
  235.  
  236. # emergency pressure valve: each time heap usage after a full (CMS)
  237. # garbage collection is above this fraction of the max, Cassandra will
  238. # flush the largest memtables.  
  239. #
  240. # Set to 1.0 to disable.  Setting this lower than
  241. # CMSInitiatingOccupancyFraction is not likely to be useful.
  242. #
  243. # RELYING ON THIS AS YOUR PRIMARY TUNING MECHANISM WILL WORK POORLY:
  244. # it is most effective under light to moderate load, or read-heavy
  245. # workloads; under truly massive write load, it will often be too
  246. # little, too late.
  247. flush_largest_memtables_at: 0.75
  248.  
  249. # emergency pressure valve #2: the first time heap usage after a full
  250. # (CMS) garbage collection is above this fraction of the max,
  251. # Cassandra will reduce cache maximum _capacity_ to the given fraction
  252. # of the current _size_.  Should usually be set substantially above
  253. # flush_largest_memtables_at, since that will have less long-term
  254. # impact on the system.  
  255. #
  256. # Set to 1.0 to disable.  Setting this lower than
  257. # CMSInitiatingOccupancyFraction is not likely to be useful.
  258. reduce_cache_sizes_at: 0.85
  259. reduce_cache_capacity_to: 0.6
  260.  
  261. # For workloads with more data than can fit in memory, Cassandra's
  262. # bottleneck will be reads that need to fetch data from
  263. # disk. "concurrent_reads" should be set to (16 * number_of_drives) in
  264. # order to allow the operations to enqueue low enough in the stack
  265. # that the OS and drives can reorder them.
  266. #
  267. # On the other hand, since writes are almost never IO bound, the ideal
  268. # number of "concurrent_writes" is dependent on the number of cores in
  269. # your system; (8 * number_of_cores) is a good rule of thumb.
  270. concurrent_reads: 32
  271. concurrent_writes: 32
  272.  
  273. # Total memory to use for memtables.  Cassandra will flush the largest
  274. # memtable when this much memory is used.
  275. # If omitted, Cassandra will set it to 1/3 of the heap.
  276. # memtable_total_space_in_mb: 2048
  277.  
  278. # Total space to use for commitlogs.  Since commitlog segments are
  279. # mmapped, and hence use up address space, the default size is 32
  280. # on 32-bit JVMs, and 1024 on 64-bit JVMs.
  281. #
  282. # If space gets above this value (it will round up to the next nearest
  283. # segment multiple), Cassandra will flush every dirty CF in the oldest
  284. # segment and remove it.  So a small total commitlog space will tend
  285. # to cause more flush activity on less-active columnfamilies.
  286. commitlog_total_space_in_mb: 8192
  287.  
  288. # This sets the amount of memtable flush writer threads.  These will
  289. # be blocked by disk io, and each one will hold a memtable in memory
  290. # while blocked. If you have a large heap and many data directories,
  291. # you can increase this value for better flush performance.
  292. # By default this will be set to the amount of data directories defined.
  293. #memtable_flush_writers: 1
  294.  
  295. # the number of full memtables to allow pending flush, that is,
  296. # waiting for a writer thread.  At a minimum, this should be set to
  297. # the maximum number of secondary indexes created on a single CF.
  298. memtable_flush_queue_size: 4
  299.  
  300. # Whether to, when doing sequential writing, fsync() at intervals in
  301. # order to force the operating system to flush the dirty
  302. # buffers. Enable this to avoid sudden dirty buffer flushing from
  303. # impacting read latencies. Almost always a good idea on SSDs; not
  304. # necessarily on platters.
  305. trickle_fsync: false
  306. trickle_fsync_interval_in_kb: 10240
  307.  
  308. # TCP port, for commands and data
  309. storage_port: 7000
  310.  
  311. # SSL port, for encrypted communication.  Unused unless enabled in
  312. # encryption_options
  313. ssl_storage_port: 7001
  314.  
  315. # Address to bind to and tell other Cassandra nodes to connect to. You
  316. # _must_ change this if you want multiple nodes to be able to
  317. # communicate!
  318. #
  319. # Leaving it blank leaves it up to InetAddress.getLocalHost(). This
  320. # will always do the Right Thing _if_ the node is properly configured
  321. # (hostname, name resolution, etc), and the Right Thing is to use the
  322. # address associated with the hostname (it might not be).
  323. #
  324. # Setting this to 0.0.0.0 is always wrong.
  325. listen_address: 192.168.135.27
  326.  
  327. # Address to broadcast to other Cassandra nodes
  328. # Leaving this blank will set it to the same value as listen_address
  329. #broadcast_address:
  330.  
  331. # Whether to start the native transport server.
  332. # Please note that the address on which the native transport is bound is the
  333. # same as the rpc_address. The port however is different and specified below.
  334. start_native_transport: false
  335. # port for the CQL native transport to listen for clients on
  336. native_transport_port: 9042
  337. # The minimum and maximum threads for handling requests when the native
  338. # transport is used. They are similar to rpc_min_threads and rpc_max_threads,
  339. # though the defaults differ slightly.
  340. # native_transport_min_threads: 16
  341. # native_transport_max_threads: 128
  342.  
  343. # Whether to start the thrift rpc server.
  344. start_rpc: true
  345.  
  346. # The address to bind the Thrift RPC service to -- clients connect
  347. # here. Unlike ListenAddress above, you _can_ specify 0.0.0.0 here if
  348. # you want Thrift to listen on all interfaces.
  349. #
  350. # Leaving this blank has the same effect it does for ListenAddress,
  351. # (i.e. it will be based on the configured hostname of the node).
  352. #rpc_address:
  353. # port for Thrift to listen for clients on
  354. rpc_port: 9160
  355.  
  356. # enable or disable keepalive on rpc connections
  357. rpc_keepalive: true
  358.  
  359. # Cassandra provides three out-of-the-box options for the RPC Server:
  360. #
  361. # sync  -> One thread per thrift connection. For a very large number of clients, memory
  362. #          will be your limiting factor. On a 64 bit JVM, 180KB is the minimum stack size
  363. #          per thread, and that will correspond to your use of virtual memory (but physical memory
  364. #          may be limited depending on use of stack space).
  365. #
  366. # hsha  -> Stands for "half synchronous, half asynchronous." All thrift clients are handled
  367. #          asynchronously using a small number of threads that does not vary with the amount
  368. #          of thrift clients (and thus scales well to many clients). The rpc requests are still
  369. #          synchronous (one thread per active request).
  370. #
  371. # The default is sync because on Windows hsha is about 30% slower.  On Linux,
  372. # sync/hsha performance is about the same, with hsha of course using less memory.
  373. #
  374. # Alternatively,  can provide your own RPC server by providing the fully-qualified class name
  375. # of an o.a.c.t.TServerFactory that can create an instance of it.
  376. rpc_server_type: sync
  377.  
  378. # Uncomment rpc_min|max_thread to set request pool size limits.
  379. #
  380. # Regardless of your choice of RPC server (see above), the number of maximum requests in the
  381. # RPC thread pool dictates how many concurrent requests are possible (but if you are using the sync
  382. # RPC server, it also dictates the number of clients that can be connected at all).
  383. #
  384. # The default is unlimited and thus provides no protection against clients overwhelming the server. You are
  385. # encouraged to set a maximum that makes sense for you in production, but do keep in mind that
  386. # rpc_max_threads represents the maximum number of client requests this server may execute concurrently.
  387. #
  388. # rpc_min_threads: 16
  389. # rpc_max_threads: 2048
  390.  
  391. # uncomment to set socket buffer sizes on rpc connections
  392. # rpc_send_buff_size_in_bytes:
  393. # rpc_recv_buff_size_in_bytes:
  394.  
  395. # Uncomment to set socket buffer size for internode communication
  396. # Note that when setting this, the buffer size is limited by net.core.wmem_max
  397. # and when not setting it it is defined by net.ipv4.tcp_wmem
  398. # See:
  399. # /proc/sys/net/core/wmem_max
  400. # /proc/sys/net/core/rmem_max
  401. # /proc/sys/net/ipv4/tcp_wmem
  402. # /proc/sys/net/ipv4/tcp_wmem
  403. # and: man tcp
  404. # internode_send_buff_size_in_bytes:
  405. # internode_recv_buff_size_in_bytes:
  406.  
  407. # Frame size for thrift (maximum message length).
  408. thrift_framed_transport_size_in_mb: 15
  409.  
  410. # Set to true to have Cassandra create a hard link to each sstable
  411. # flushed or streamed locally in a backups/ subdirectory of the
  412. # keyspace data.  Removing these links is the operator's
  413. # responsibility.
  414. incremental_backups: false
  415.  
  416. # Whether or not to take a snapshot before each compaction.  Be
  417. # careful using this option, since Cassandra won't clean up the
  418. # snapshots for you.  Mostly useful if you're paranoid when there
  419. # is a data format change.
  420. snapshot_before_compaction: false
  421.  
  422. # Whether or not a snapshot is taken of the data before keyspace truncation
  423. # or dropping of column families. The STRONGLY advised default of true
  424. # should be used to provide data safety. If you set this flag to false, you will
  425. # lose data on truncation or drop.
  426. auto_snapshot: true
  427.  
  428. # Add column indexes to a row after its contents reach this size.
  429. # Increase if your column values are large, or if you have a very large
  430. # number of columns.  The competing causes are, Cassandra has to
  431. # deserialize this much of the row to read a single column, so you want
  432. # it to be small - at least if you do many partial-row reads - but all
  433. # the index data is read for each access, so you don't want to generate
  434. # that wastefully either.
  435. column_index_size_in_kb: 64
  436.  
  437. # Size limit for rows being compacted in memory.  Larger rows will spill
  438. # over to disk and use a slower two-pass compaction process.  A message
  439. # will be logged specifying the row key.
  440. in_memory_compaction_limit_in_mb: 64
  441.  
  442. # Number of simultaneous compactions to allow, NOT including
  443. # validation "compactions" for anti-entropy repair.  Simultaneous
  444. # compactions can help preserve read performance in a mixed read/write
  445. # workload, by mitigating the tendency of small sstables to accumulate
  446. # during a single long running compactions. The default is usually
  447. # fine and if you experience problems with compaction running too
  448. # slowly or too fast, you should look at
  449. # compaction_throughput_mb_per_sec first.
  450. #
  451. # concurrent_compactors defaults to the number of cores.
  452. # Uncomment to make compaction mono-threaded, the pre-0.8 default.
  453. #concurrent_compactors: 1
  454.  
  455. # Multi-threaded compaction. When enabled, each compaction will use
  456. # up to one thread per core, plus one thread per sstable being merged.
  457. # This is usually only useful for SSD-based hardware: otherwise,
  458. # your concern is usually to get compaction to do LESS i/o (see:
  459. # compaction_throughput_mb_per_sec), not more.
  460. multithreaded_compaction: false
  461.  
  462. # Throttles compaction to the given total throughput across the entire
  463. # system. The faster you insert data, the faster you need to compact in
  464. # order to keep the sstable count down, but in general, setting this to
  465. # 16 to 32 times the rate you are inserting data is more than sufficient.
  466. # Setting this to 0 disables throttling. Note that this account for all types
  467. # of compaction, including validation compaction.
  468. compaction_throughput_mb_per_sec: 16
  469.  
  470. # Track cached row keys during compaction, and re-cache their new
  471. # positions in the compacted sstable.  Disable if you use really large
  472. # key caches.
  473. compaction_preheat_key_cache: true
  474.  
  475. # Throttles all outbound streaming file transfers on this node to the
  476. # given total throughput in Mbps. This is necessary because Cassandra does
  477. # mostly sequential IO when streaming data during bootstrap or repair, which
  478. # can lead to saturating the network connection and degrading rpc performance.
  479. # When unset, the default is 200 Mbps or 25 MB/s.
  480. # stream_throughput_outbound_megabits_per_sec: 200
  481.  
  482. # How long the coordinator should wait for read operations to complete
  483. read_request_timeout_in_ms: 10000
  484. # How long the coordinator should wait for seq or index scans to complete
  485. range_request_timeout_in_ms: 10000
  486. # How long the coordinator should wait for writes to complete
  487. write_request_timeout_in_ms: 10000
  488. # How long the coordinator should wait for truncates to complete
  489. # (This can be much longer, because unless auto_snapshot is disabled
  490. # we need to flush first so we can snapshot before removing the data.)
  491. truncate_request_timeout_in_ms: 60000
  492. # The default timeout for other, miscellaneous operations
  493. request_timeout_in_ms: 10000
  494.  
  495. # Enable operation timeout information exchange between nodes to accurately
  496. # measure request timeouts, If disabled cassandra will assuming the request
  497. # was forwarded to the replica instantly by the coordinator
  498. #
  499. # Warning: before enabling this property make sure to ntp is installed
  500. # and the times are synchronized between the nodes.
  501. cross_node_timeout: false
  502.  
  503. # Enable socket timeout for streaming operation.
  504. # When a timeout occurs during streaming, streaming is retried from the start
  505. # of the current file. This _can_ involve re-streaming an important amount of
  506. # data, so you should avoid setting the value too low.
  507. # Default value is 0, which never timeout streams.
  508. # streaming_socket_timeout_in_ms: 0
  509.  
  510. # phi value that must be reached for a host to be marked down.
  511. # most users should never need to adjust this.
  512. # phi_convict_threshold: 8
  513.  
  514. # endpoint_snitch -- Set this to a class that implements
  515. # IEndpointSnitch.  The snitch has two functions:
  516. # - it teaches Cassandra enough about your network topology to route
  517. #   requests efficiently
  518. # - it allows Cassandra to spread replicas around your cluster to avoid
  519. #   correlated failures. It does this by grouping machines into
  520. #   "datacenters" and "racks."  Cassandra will do its best not to have
  521. #   more than one replica on the same "rack" (which may not actually
  522. #   be a physical location)
  523. #
  524. # IF YOU CHANGE THE SNITCH AFTER DATA IS INSERTED INTO THE CLUSTER,
  525. # YOU MUST RUN A FULL REPAIR, SINCE THE SNITCH AFFECTS WHERE REPLICAS
  526. # ARE PLACED.
  527. #
  528. # Out of the box, Cassandra provides
  529. #  - SimpleSnitch:
  530. #    Treats Strategy order as proximity. This improves cache locality
  531. #    when disabling read repair, which can further improve throughput.
  532. #    Only appropriate for single-datacenter deployments.
  533. #  - PropertyFileSnitch:
  534. #    Proximity is determined by rack and data center, which are
  535. #    explicitly configured in cassandra-topology.properties.
  536. #  - GossipingPropertyFileSnitch
  537. #    The rack and datacenter for the local node are defined in
  538. #    cassandra-rackdc.properties and propagated to other nodes via gossip.  If
  539. #    cassandra-topology.properties exists, it is used as a fallback, allowing
  540. #    migration from the PropertyFileSnitch.
  541. #  - RackInferringSnitch:
  542. #    Proximity is determined by rack and data center, which are
  543. #    assumed to correspond to the 3rd and 2nd octet of each node's
  544. #    IP address, respectively.  Unless this happens to match your
  545. #    deployment conventions (as it did Facebook's), this is best used
  546. #    as an example of writing a custom Snitch class.
  547. #  - Ec2Snitch:
  548. #    Appropriate for EC2 deployments in a single Region. Loads Region
  549. #    and Availability Zone information from the EC2 API. The Region is
  550. #    treated as the datacenter, and the Availability Zone as the rack.
  551. #    Only private IPs are used, so this will not work across multiple
  552. #    Regions.
  553. #  - Ec2MultiRegionSnitch:
  554. #    Uses public IPs as broadcast_address to allow cross-region
  555. #    connectivity.  (Thus, you should set seed addresses to the public
  556. #    IP as well.) You will need to open the storage_port or
  557. #    ssl_storage_port on the public IP firewall.  (For intra-Region
  558. #    traffic, Cassandra will switch to the private IP after
  559. #    establishing a connection.)
  560. #
  561. # You can use a custom Snitch by setting this to the full class name
  562. # of the snitch, which will be assumed to be on your classpath.
  563. endpoint_snitch: Ec2Snitch
  564.  
  565. # controls how often to perform the more expensive part of host score
  566. # calculation
  567. dynamic_snitch_update_interval_in_ms: 100
  568. # controls how often to reset all host scores, allowing a bad host to
  569. # possibly recover
  570. dynamic_snitch_reset_interval_in_ms: 600000
  571. # if set greater than zero and read_repair_chance is < 1.0, this will allow
  572. # 'pinning' of replicas to hosts in order to increase cache capacity.
  573. # The badness threshold will control how much worse the pinned host has to be
  574. # before the dynamic snitch will prefer other replicas over it.  This is
  575. # expressed as a double which represents a percentage.  Thus, a value of
  576. # 0.2 means Cassandra would continue to prefer the static snitch values
  577. # until the pinned host was 20% worse than the fastest.
  578. dynamic_snitch_badness_threshold: 0.1
  579.  
  580. # request_scheduler -- Set this to a class that implements
  581. # RequestScheduler, which will schedule incoming client requests
  582. # according to the specific policy. This is useful for multi-tenancy
  583. # with a single Cassandra cluster.
  584. # NOTE: This is specifically for requests from the client and does
  585. # not affect inter node communication.
  586. # org.apache.cassandra.scheduler.NoScheduler - No scheduling takes place
  587. # org.apache.cassandra.scheduler.RoundRobinScheduler - Round robin of
  588. # client requests to a node with a separate queue for each
  589. # request_scheduler_id. The scheduler is further customized by
  590. # request_scheduler_options as described below.
  591. request_scheduler: org.apache.cassandra.scheduler.NoScheduler
  592.  
  593. # Scheduler Options vary based on the type of scheduler
  594. # NoScheduler - Has no options
  595. # RoundRobin
  596. #  - throttle_limit -- The throttle_limit is the number of in-flight
  597. #                      requests per client.  Requests beyond
  598. #                      that limit are queued up until
  599. #                      running requests can complete.
  600. #                      The value of 80 here is twice the number of
  601. #                      concurrent_reads + concurrent_writes.
  602. #  - default_weight -- default_weight is optional and allows for
  603. #                      overriding the default which is 1.
  604. #  - weights -- Weights are optional and will default to 1 or the
  605. #               overridden default_weight. The weight translates into how
  606. #               many requests are handled during each turn of the
  607. #               RoundRobin, based on the scheduler id.
  608. #
  609. # request_scheduler_options:
  610. #    throttle_limit: 80
  611. #    default_weight: 5
  612. #    weights:
  613. #      Keyspace1: 1
  614. #      Keyspace2: 5
  615.  
  616. # request_scheduler_id -- An identifier based on which to perform
  617. # the request scheduling. Currently the only valid option is keyspace.
  618. # request_scheduler_id: keyspace
  619.  
  620. # index_interval controls the sampling of entries from the primrary
  621. # row index in terms of space versus time.  The larger the interval,
  622. # the smaller and less effective the sampling will be.  In technicial
  623. # terms, the interval coresponds to the number of index entries that
  624. # are skipped between taking each sample.  All the sampled entries
  625. # must fit in memory.  Generally, a value between 128 and 512 here
  626. # coupled with a large key cache size on CFs results in the best trade
  627. # offs.  This value is not often changed, however if you have many
  628. # very small rows (many to an OS page), then increasing this will
  629. # often lower memory usage without a impact on performance.
  630. index_interval: 128
  631.  
  632. # Enable or disable inter-node encryption
  633. # Default settings are TLS v1, RSA 1024-bit keys (it is imperative that
  634. # users generate their own keys) TLS_RSA_WITH_AES_128_CBC_SHA as the cipher
  635. # suite for authentication, key exchange and encryption of the actual data transfers.
  636. # NOTE: No custom encryption options are enabled at the moment
  637. # The available internode options are : all, none, dc, rack
  638. #
  639. # If set to dc cassandra will encrypt the traffic between the DCs
  640. # If set to rack cassandra will encrypt the traffic between the racks
  641. #
  642. # The passwords used in these options must match the passwords used when generating
  643. # the keystore and truststore.  For instructions on generating these files, see:
  644. # http://download.oracle.com/javase/6/docs/technotes/guides/security/jsse/JSSERefGuide.html#CreateKeystore
  645. #
  646. server_encryption_options:
  647.     internode_encryption: none
  648.     keystore: conf/.keystore
  649.     keystore_password: cassandra
  650.     truststore: conf/.truststore
  651.     truststore_password: cassandra
  652.     # More advanced defaults below:
  653.     # protocol: TLS
  654.     # algorithm: SunX509
  655.     # store_type: JKS
  656.     # cipher_suites: [TLS_RSA_WITH_AES_128_CBC_SHA,TLS_RSA_WITH_AES_256_CBC_SHA]
  657.     # require_client_auth: false
  658.  
  659. # enable or disable client/server encryption.
  660. client_encryption_options:
  661.     enabled: false
  662.     keystore: conf/.keystore
  663.     keystore_password: cassandra
  664.     # require_client_auth: false
  665.     # Set trustore and truststore_password if require_client_auth is true
  666.     # truststore: conf/.truststore
  667.     # truststore_password: cassandra
  668.     # More advanced defaults below:
  669.     # protocol: TLS
  670.     # algorithm: SunX509
  671.     # store_type: JKS
  672.     # cipher_suites: [TLS_RSA_WITH_AES_128_CBC_SHA,TLS_RSA_WITH_AES_256_CBC_SHA]
  673.  
  674. # internode_compression controls whether traffic between nodes is
  675. # compressed.
  676. # can be:  all  - all traffic is compressed
  677. #          dc   - traffic between different datacenters is compressed
  678. #          none - nothing is compressed.
  679. internode_compression: all
  680.  
  681. # Enable or disable tcp_nodelay for inter-dc communication.
  682. # Disabling it will result in larger (but fewer) network packets being sent,
  683. # reducing overhead from the TCP protocol itself, at the cost of increasing
  684. # latency if you block for cross-datacenter responses.
  685. inter_dc_tcp_nodelay: true
Advertisement
Add Comment
Please, Sign In to add comment
Advertisement